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

A

abandonedEventOperatorSet - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
abbreviate(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
convert "From src insert blah blah" to "From src insert ...
abort - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
abort(WriterContext) - Method in class org.apache.hive.hcatalog.data.transfer.HCatWriter
This method should be called at master node.
abort(WriterContext) - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
abort() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Abort the currently open transaction
abort(Executor) - Method in class org.apache.hive.jdbc.HiveConnection
 
abort_txn(AbortTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.abort_txn_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
abort_txn(AbortTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.abort_txn_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
abort_txn(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
abort_txn(AbortTxnRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
abort_txn(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
abortJob(OutputFormat, Job) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
abortJob(JobContext, JobStatus.State) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry
Trigger abort for TaskAttempt, as specified by the TaskAttemptContext argument.
abortTask(TaskAttemptContext) - Method in interface org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry.TaskCommitterProxy
Call-back for Committer's abortTask().
abortTxn(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
AbortTxnRequest - Class in org.apache.hadoop.hive.metastore.api
 
AbortTxnRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
AbortTxnRequest(long) - Constructor for class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
AbortTxnRequest(AbortTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
Performs a deep copy on other.
AbortTxnRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
abortWriters(FileSystem, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
abs() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
abs(SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
abs(int, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
abs(int, HiveDecimalWritable, 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
 
absDestructive() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Makes this Decimal128 a positive number.
absDestructive() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Makes this object positive.
absolute(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
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
 
AbstractCommandHandler - Class in org.apache.hive.beeline
An abstract implementation of CommandHandler.
AbstractCommandHandler(BeeLine, String[], String, Completer[]) - Constructor for class org.apache.hive.beeline.AbstractCommandHandler
 
AbstractDeserializer - Class in org.apache.hadoop.hive.serde2
Abstract class for implementing Deserializer.
AbstractDeserializer() - Constructor for class org.apache.hadoop.hive.serde2.AbstractDeserializer
 
AbstractEncodingAwareSerDe - Class in org.apache.hadoop.hive.serde2
AbstractEncodingAwareSerDe aware the encoding from table properties, transform data from specified charset to UTF-8 during serialize, and transform data from UTF-8 to specified charset during deserialize.
AbstractEncodingAwareSerDe() - Constructor for class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
AbstractFileMergeOperator<T extends FileMergeDesc> - Class in org.apache.hadoop.hive.ql.exec
Fast file merge operator for ORC and RCfile.
AbstractFileMergeOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
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.BeginChecker - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Matches the beginning of each string to a pattern.
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.
AbstractFilterStringColLikeStringScalar.CheckerFactory - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
A CheckerFactory creates checkers of its kind.
AbstractFilterStringColLikeStringScalar.ComplexChecker - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Matches each string to a pattern with Java regular expression package.
AbstractFilterStringColLikeStringScalar.EndChecker - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Matches the ending of each string to its pattern.
AbstractFilterStringColLikeStringScalar.MiddleChecker - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Matches the middle of each string to its pattern.
AbstractFilterStringColLikeStringScalar.NoneChecker - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Matches the whole string to its pattern.
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
 
AbstractHBaseKeyFactory - Class in org.apache.hadoop.hive.hbase
 
AbstractHBaseKeyFactory() - Constructor for class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
AbstractHBaseKeyPredicateDecomposer - Class in org.apache.hadoop.hive.hbase
Simple abstract class to help with creation of a HiveStoragePredicateHandler.DecomposedPredicate.
AbstractHBaseKeyPredicateDecomposer() - Constructor for class org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer
 
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
 
AbstractMapJoinTableContainer(Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
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
 
AbstractPrimitiveJavaObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
An AbstractJavaPrimitiveObjectInspector for a Java object.
AbstractPrimitiveJavaObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
AbstractPrimitiveJavaObjectInspector(PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
AbstractPrimitiveLazyObjectInspector<T extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
An AbstractPrimitiveLazyObjectInspector for a LazyPrimitive object.
AbstractPrimitiveLazyObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.AbstractPrimitiveLazyObjectInspector
 
AbstractPrimitiveLazyObjectInspector(PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.AbstractPrimitiveLazyObjectInspector
 
AbstractPrimitiveObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
An AbstractPrimitiveObjectInspector is based on ObjectInspectorUtils.PrimitiveTypeEntry.
AbstractPrimitiveObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
 
AbstractPrimitiveObjectInspector(PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Construct a AbstractPrimitiveObjectInspector.
AbstractPrimitiveWritableObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
An AbstractWritablePrimitiveObjectInspector for a Writable object.
AbstractPrimitiveWritableObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
AbstractPrimitiveWritableObjectInspector(PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
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
 
AbstractSerDe - Class in org.apache.hadoop.hive.serde2
Abstract class for implementing SerDe.
AbstractSerDe() - Constructor for class org.apache.hadoop.hive.serde2.AbstractSerDe
 
AbstractSerializer - Class in org.apache.hadoop.hive.serde2
Abstract class for implementing Serializer.
AbstractSerializer() - Constructor for class org.apache.hadoop.hive.serde2.AbstractSerializer
 
AbstractService - Class in org.apache.hive.service
AbstractService.
AbstractService(String) - Constructor for class org.apache.hive.service.AbstractService
Construct the service.
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
 
AbstractStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
AbstractStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.AbstractStorageFormatDescriptor
 
AbstractVectorDesc - Class in org.apache.hadoop.hive.ql.plan
 
AbstractVectorDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AbstractVectorDesc
 
accept(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.CompareOp
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Equal
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThan
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThanOrEqual
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThan
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThanOrEqual
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Like
 
accept(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.NotEqual
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.DisabledQFileFilter
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.IncludeFilter
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.QFileRegexFilter
 
accept(NotificationEvent) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient.NotificationFilter
Whether a notification event should be accepted
accept(ExpressionTree.TreeVisitor) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
 
accept(ExpressionTree.TreeVisitor) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
accept(ExpressionTree.TreeVisitor) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
Double dispatch for TreeVisitor.
accept(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
accept(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
accepted(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
acceptImpl() - Method in class org.apache.hadoop.hive.metastore.TServerSocketKeepAlive
 
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
 
acceptsURL(String) - Method in class org.apache.hive.jdbc.HiveDriver
Checks whether a given url is in a valid format.
accessMethod - Static variable in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
ACCUMULO_SERVICE - Static variable in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
 
AccumuloCompositeRowId - Class in org.apache.hadoop.hive.accumulo.serde
AccumuloCompositeKey extension of LazyStruct.
AccumuloCompositeRowId(LazySimpleStructObjectInspector) - Constructor for class org.apache.hadoop.hive.accumulo.serde.AccumuloCompositeRowId
 
AccumuloConnectionParameters - Class in org.apache.hadoop.hive.accumulo
 
AccumuloConnectionParameters(Configuration) - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
AccumuloHiveConstants - Class in org.apache.hadoop.hive.accumulo
 
AccumuloHiveConstants() - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
AccumuloHiveRow - Class in org.apache.hadoop.hive.accumulo
Holds column tuples for rowID.
AccumuloHiveRow() - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
AccumuloHiveRow(String) - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
AccumuloHiveRow.ColumnTuple - Class in org.apache.hadoop.hive.accumulo
 
AccumuloHiveRow.ColumnTuple(Text, Text, byte[]) - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
accumuloInputFormat - Variable in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
AccumuloPredicateHandler - Class in org.apache.hadoop.hive.accumulo.predicate
Supporting operations dealing with Hive Predicate pushdown to iterators and ranges.
AccumuloRangeGenerator - Class in org.apache.hadoop.hive.accumulo.predicate
 
AccumuloRangeGenerator(AccumuloPredicateHandler, HiveAccumuloRowIdColumnMapping, String) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
AccumuloRowIdFactory - Interface in org.apache.hadoop.hive.accumulo.serde
Interface for providing custom Accumulo RowID generation/parsing
AccumuloRowSerializer - Class in org.apache.hadoop.hive.accumulo.serde
Serializes a Struct to an Accumulo row as per the definition provided by the ColumnMappings
AccumuloRowSerializer(int, LazySerDeParameters, List<ColumnMapping>, ColumnVisibility, AccumuloRowIdFactory) - Constructor for class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
AccumuloSerDe - Class in org.apache.hadoop.hive.accumulo.serde
Deserialization from Accumulo to LazyAccumuloRow for Hive.
AccumuloSerDe() - Constructor for class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
AccumuloSerDeParameters - Class in org.apache.hadoop.hive.accumulo.serde
 
AccumuloSerDeParameters(Configuration, Properties, String) - Constructor for class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
accumuloSerDeParams - Variable in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
AccumuloStorageHandler - Class in org.apache.hadoop.hive.accumulo
Create table mapping to Accumulo for Hive.
AccumuloStorageHandler() - Constructor for class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
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
 
acidAddRowToBatch(Object, StructObjectInspector, int, VectorizedRowBatch, VectorizedRowBatchCtx, 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 from a given offset
acidFileSinks - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
A set of FileSinkOperators being written to in an ACID compliant way.
AcidInputFormat<KEY extends org.apache.hadoop.io.WritableComparable,VALUE> - Interface in org.apache.hadoop.hive.ql.io
The interface required for input formats that what to support ACID transactions.
AcidInputFormat.AcidRecordReader<K,V> - Interface in org.apache.hadoop.hive.ql.io
RecordReader returned by AcidInputFormat working in row-at-a-time mode should AcidRecordReader.
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<K extends org.apache.hadoop.io.WritableComparable,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.Operation - Enum in org.apache.hadoop.hive.ql.io
 
AcidUtils.ParsedDelta - Class in org.apache.hadoop.hive.ql.io
 
acquire(boolean) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
acquire(boolean) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
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.
activateOptions() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
adapatorDirectAccess - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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.
adaptPutRow(VectorMapJoinFastBytesHashTable, BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringCommon
 
add(String, String, byte[]) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
add(Text, Text, byte[]) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
add(HiveInterruptCallback) - Static method in class org.apache.hadoop.hive.common.HiveInterruptUtils
 
add(Decimal128, Decimal128, Decimal128, short) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Calculates addition and puts the result into the given object.
add(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
add(SignedInt128, SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
Calculates addition and puts the result into the given object.
add(String, String, String, long, ColumnStatisticsObj, BloomFilter) - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
Add a new node to the cache; may trigger the cleaner thread if the cache is near full capacity.
add(MapJoinObjectSerDeContext, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
Called when loading the hashtable.
add(int, Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
add(HiveKey, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
add(ROW) - Method in class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
add(SparkCounters) - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticsBuilder
 
add(String, String, String) - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticsBuilder
 
add(byte[], int, int, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
add(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastKeyStore
 
add(long, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
add(int, int, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
add(int, int, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
add(int, int, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOutputMapping
 
add(int, int, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSourceMapping
 
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(RowResolver, RowResolver, int) - Static method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
add(RowResolver, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
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.SparkWork
add creates a new node in the graph without any connections
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(Timestamp, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
add(Date, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
add(HiveIntervalYearMonth, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
add(Timestamp, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
add(HiveIntervalDayTime, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
add(byte[]) - Method in class org.apache.hive.common.util.BloomFilter
 
add_dynamic_partitions(AddDynamicPartitions, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_dynamic_partitions(AddDynamicPartitions, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_dynamic_partitions(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_dynamic_partitions(AddDynamicPartitions) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_dynamic_partitions(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_escapes(String) - Method in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
add_index(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_index(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_index(Index, Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partition(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partition(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partition(Partition) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partition(Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partition(Partition) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Add a partition to the table.
add_partition_with_environment_context(Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partition_with_environment_context(Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partition_with_environment_context(Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partition_with_environment_context(Partition, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partition_with_environment_context(Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partitions(List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partitions(List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partitions(List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partitions(List<Partition>, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partitions(List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Add partitions to the table.
add_partitions(List<Partition>, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Add partitions to the table.
add_partitions_pspec(List<PartitionSpec>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partitions_pspec(List<PartitionSpec>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partitions_pspec(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partitions_pspec(List<PartitionSpec>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partitions_pspec(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partitions_pspec(PartitionSpecProxy) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partitions_pspec(PartitionSpecProxy) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
add_partitions_req(AddPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_req_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partitions_req(AddPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_req_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partitions_req(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partitions_req(AddPartitionsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partitions_req(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
add_resources(SessionState.ResourceType, Collection<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
add_resources(SessionState.ResourceType, Collection<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.FlatRowContainer
 
addAll(Collection<BaseWork>) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
Add all nodes in the collection without any connections.
addAll(BaseWork[]) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
Add all nodes in the collection without any connections.
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
 
addAllBitset(Iterable<? extends Long>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
addAllBloomFilter(Iterable<? extends OrcProto.BloomFilter>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addAllColStats(Iterable<? extends OrcProto.ColumnStatistics>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addAllColumns(Iterable<? extends OrcProto.ColumnEncoding>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addAllCount(Iterable<? extends Long>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
addAllEntry(Iterable<? extends OrcProto.RowIndexEntry>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addAllFieldNames(Iterable<String>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
addAllMetadata(Iterable<? extends OrcProto.UserMetadataItem>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addAllParents(Node) - Method in class org.apache.hadoop.hive.ql.lib.ForwardWalker
 
addAllPositions(Iterable<? extends Long>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
addAllStatistics(Iterable<? extends OrcProto.ColumnStatistics>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addAllStreams(Iterable<? extends OrcProto.Stream>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addAllStripes(Iterable<? extends OrcProto.StripeInformation>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addAllStripeStats(Iterable<? extends OrcProto.StripeStatistics>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addAllSubtypes(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
addAllTypes(Iterable<? extends OrcProto.Type>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addAllVersion(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
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
 
addArgs(List<String>) - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
Add hcat args.
addBatch() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
addBatch(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
addBatch() - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
addBatch(String) - Method in class org.apache.hive.jdbc.HiveStatement
 
addBinary(Binary) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
addBinary(Binary) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addBitset(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
addBloomFilter(OrcProto.BloomFilter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBloomFilter(int, OrcProto.BloomFilter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBloomFilter(OrcProto.BloomFilter.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBloomFilter(int, OrcProto.BloomFilter.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBloomFilterBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBloomFilterBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
addBoolean(boolean) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addBytes(byte[], int) - Method in class org.apache.hive.common.util.BloomFilter
 
addCachedRDDId(int) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
addCacheFile(URI, Job) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Does exactly what org.apache.hadoop.mapreduce.Job#addCacheFile(URI) in Hadoop 2.
addCacheFile(URI, Job) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
 
addCacheFile(URI, Job) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
 
addCacheFiles(List<String>, AppConfig) - Static method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
Add files to the Distributed Cache for the controller job.
addCandidateFilterOp(FilterOperator) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
addChecked(int, HiveDecimal, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
addChecked(int, HiveDecimalWritable, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
addChecked(int, HiveDecimalWritable, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
addChecked(int, HiveDecimal, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
addChild(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Add a jobid to the list of children of this job.
addCmdForWindows(ArrayList<String>) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
addColStats(OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColStats(int, OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColStats(OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColStats(int, OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColStatsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColStatsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
addColumn(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
addColumnColumnFilterTestCases(String, String, String, String) - Method in class org.apache.hadoop.hive.ant.GenVectorTestCode
 
addColumnColumnOperationTestCases(String, String, String, String) - Method in class org.apache.hadoop.hive.ant.GenVectorTestCode
 
addColumns(OrcProto.ColumnEncoding) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumns(int, OrcProto.ColumnEncoding) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumns(OrcProto.ColumnEncoding.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumns(int, OrcProto.ColumnEncoding.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumnsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumnsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
addColumnScalarFilterTestCases(boolean, String, String, String, String) - Method in class org.apache.hadoop.hive.ant.GenVectorTestCode
 
addColumnScalarOperationTestCases(boolean, String, String, String, String) - Method in class org.apache.hadoop.hive.ant.GenVectorTestCode
 
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.
addComparisonOp(String, String...) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
add allowed functions per column
addCompleteTask(TaskRunner) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
addConstructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
addConvertedNode(ExprNodeDesc, ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
adds a replacement node for this expression.
addCorrelation(IntraQueryCorrelation) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
addCount(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
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
 
addDef(List<String>, String, String) - Static method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
Add a Hadoop command line definition to args if the value is not null.
addDelegationTokens(FileSystem, Credentials, String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
addDelegationTokens(FileSystem, Credentials, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
addDelegationTokens(FileSystem, Credentials, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get Delegation token and add it to Credential.
addDelegationTokens(FileSystem, Credentials, String) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
addDependency(JSONObject, Map<String, Stage>) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Stage
 
addDependency(Connection) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
addDependencyJars(Configuration) - Method in interface org.apache.hadoop.hive.accumulo.serde.AccumuloRowIdFactory
Add this implementation to the classpath for the Job
addDependencyJars(Configuration) - Method in class org.apache.hadoop.hive.accumulo.serde.CompositeAccumuloRowIdFactory
 
addDependencyJars(Configuration) - Method in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hive.accumulo.Utils
 
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.
addDestructive(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Calculates addition and stores the result into this object.
addDestructive(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Calculates addition and stores the result into this object.
addDestructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Adds the given value to this value.
addDestructive(int[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Adds the given value to this value.
addDestructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Adds the given value to this value.
addDestructiveScaleTen(UnsignedInt128, short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Adds the given value after scaling to this value.
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
 
addDouble(double) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addDouble(double) - Method in class org.apache.hive.common.util.BloomFilter
 
addDummyOp(HashTableDummyOperator) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
addDummyOp(HashTableDummyOperator) - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
addDummyParentOp(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
AddDynamicPartitions - Class in org.apache.hadoop.hive.metastore.api
 
AddDynamicPartitions() - Constructor for class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
AddDynamicPartitions(long, String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
AddDynamicPartitions(AddDynamicPartitions) - Constructor for class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Performs a deep copy on other.
addDynamicPartitions(long, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
addDynamicPartitions(long, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Send a list of partitions to the metastore to indicate which partitions were loaded dynamically.
addDynamicPartitions(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
AddDynamicPartitions._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
addEntry(OrcProto.RowIndexEntry) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addEntry(int, OrcProto.RowIndexEntry) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addEntry(OrcProto.RowIndexEntry.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addEntry(int, OrcProto.RowIndexEntry.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addEntryBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
addEntryBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
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
 
addEnv(Map<String, String>) - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
Add Hadoop env variables.
addEscapes(String) - Static method in error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addEvent(InputInitializerEvent) - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
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
 
addField(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableUnionObjectInspector
 
addField(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
addField(FieldSchema) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.CollectionBuilder
 
addField(HCatFieldSchema) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.CollectionBuilder
 
addFieldNames(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
addFieldNamesBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
addFile(URI) - Method in interface org.apache.hive.spark.client.SparkClient
Adds a file to the running remote context.
addFilter(Filter) - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
addFilter(Filter) - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
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).
addFinalCandidate(String, ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
addFirst(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore
 
addFloat(float) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addFunctionResources(FunctionInfo.FunctionResource[]) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
addHiveconfToSystemProperties() - Method in class org.apache.hadoop.hive.common.cli.CommonCliOptions
Add the hiveconf properties to the Java system properties, override anything therein.
addHivePersistenceDelegates(XMLEncoder) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
addHttpAuthHeader(HttpRequest, HttpContext) - Method in class org.apache.hive.jdbc.HttpBasicAuthInterceptor
 
addHttpAuthHeader(HttpRequest, HttpContext) - Method in class org.apache.hive.jdbc.HttpKerberosRequestInterceptor
 
addHttpAuthHeader(HttpRequest, HttpContext) - Method in class org.apache.hive.jdbc.HttpRequestInterceptorBase
 
addIndex(Index) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addIndex(Index) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
AddIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
AddIndexEvent(Index, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AddIndexEvent
 
addIndexIntermediateFile(String) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
addInitialColumn(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
addInline(Op, Connection) - Static method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
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
 
addInt(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addIntermediateNode(ExpressionTree.LogicalOperator) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Adds a intermediate node of either type(AND/OR).
addIterators(JobConf, List<IteratorSetting>) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
addJar(URI) - Method in interface org.apache.hive.spark.client.SparkClient
Adds a jar file to the running remote context.
addKey(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
addLateralViewForAlias(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addLeafNode(ExpressionTree.LeafNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Adds a leaf node, pushes the new node onto the stack.
addLine(String) - Method in class org.apache.hive.beeline.OutputFile
 
addListener(JobHandle.Listener<T>) - Method in interface org.apache.hive.spark.client.JobHandle
Add a listener to the job handle.
addListener(Rpc.Listener) - Method in class org.apache.hive.spark.client.rpc.Rpc
 
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
 
addLocalDriverClazz(String) - Method in class org.apache.hive.beeline.BeeLine
 
addlocaldriverjar(String) - Method in class org.apache.hive.beeline.Commands
 
addlocaldrivername(String) - Method in class org.apache.hive.beeline.Commands
 
addLocalMapRedErrors(String, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
addLockComponent(LockComponent) - Method in class org.apache.hadoop.hive.metastore.LockRequestBuilder
Add a lock component to the lock request
addLong(long) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addLong(long) - Method in class org.apache.hive.common.util.BloomFilter
 
addMappingOnly(String, String, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
addMapWork(String, String, Operator<?>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
addMasterKey(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addMasterKey(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addMasterKey(String) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
addMasterKey(String) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Add new master key.
addMasterKey(String) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
addMasterKey(String) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
addMergedWork(BaseWork, BaseWork, Map<Operator<?>, BaseWork>) - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
addMetadata(OrcProto.UserMetadataItem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMetadata(int, OrcProto.UserMetadataItem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMetadata(OrcProto.UserMetadataItem.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMetadata(int, OrcProto.UserMetadataItem.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMetadataBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMetadataBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
addMissingPrivMsg(Collection<SQLPrivTypeGrant>, HivePrivilegeObject, List<String>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
 
addMonth(Date, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAddMonths
 
addMonthsToDays(long, int) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
addMonthsToMillisLocal(long, int) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
Perform month arithmetic to millis value using local time zone.
addMonthsToMillisUtc(long, int) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
Perform month arithmetic to millis value using UTC time zone.
addMonthsToNanosLocal(long, int) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
addMonthsToNanosUtc(long, int) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
addMore(long, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore
 
addNonFinalCandidate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified expr as a non-final candidate
addNotificationEvent(NotificationEvent) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addNotificationEvent(NotificationEvent) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Add a notification entry.
addOIPropertiestoSerDePropsMap(StructObjectInspector, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
addOneColumn(String, String, String, ColumnDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Add one column.
addOneColumn(String, String, String, ColumnDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
Create a column in an hcat table.
addOnePartition(String, String, String, PartitionDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Add one partition.
addOnePartition(String, String, String, PartitionDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
Create a partition in an hcat table.
addOneTableProperty(String, String, String, TablePropertyDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Add one table property.
addOneTableProperty(String, String, String, TablePropertyDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
Add a single property on an hcat table.
addOperatorTableAccess(Operator<? extends OperatorDesc>, Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.parse.TableAccessCtx
 
addOpToDelete(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
addOrMerge(long, long, boolean, boolean) - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListCreateHelper
 
addOutputFormat(String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.JobConfigurer
Add a OutputFormat configuration to the Job with a alias name.
addPartition(Partition) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addPartition(Partition) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addPartition(Map<String, String>, String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
addPartition(HCatAddPartitionDesc) - Method in class org.apache.hive.hcatalog.api.HCatClient
Adds the partition.
addPartition(HCatAddPartitionDesc) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
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
 
AddPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
AddPartitionEvent(Table, List<Partition>, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AddPartitionEvent
 
AddPartitionEvent(Table, Partition, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AddPartitionEvent
 
AddPartitionEvent(Table, PartitionSpecProxy, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AddPartitionEvent
Alternative constructor to use PartitionSpec APIs.
addPartitionExpressionsToOrderList(ArrayList<PTFInvocationSpec.PartitionExpression>, ArrayList<PTFInvocationSpec.OrderExpression>) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
AddPartitionMessage - Class in org.apache.hive.hcatalog.messaging
The HCat message sent when partition(s) are added to a table.
AddPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.AddPartitionMessage
 
AddPartitionReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
AddPartitionReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.AddPartitionReplicationTask
 
addPartitions(String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addPartitions(String, String, PartitionSpecProxy, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addPartitions(String, String, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addPartitions(String, String, PartitionSpecProxy, boolean) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addPartitions(List<HCatAddPartitionDesc>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Adds a list of partitions.
addPartitions(List<HCatAddPartitionDesc>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
addPartitionSpec(HCatPartitionSpec) - Method in class org.apache.hive.hcatalog.api.HCatClient
Adds partitions using HCatPartitionSpec.
addPartitionSpec(HCatPartitionSpec) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
AddPartitionsRequest - Class in org.apache.hadoop.hive.metastore.api
 
AddPartitionsRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
AddPartitionsRequest(String, String, List<Partition>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
AddPartitionsRequest(AddPartitionsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Performs a deep copy on other.
AddPartitionsRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AddPartitionsResult - Class in org.apache.hadoop.hive.metastore.api
 
AddPartitionsResult() - Constructor for class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
AddPartitionsResult(AddPartitionsResult) - Constructor for class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
Performs a deep copy on other.
AddPartitionsResult._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
addPositions(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
addPostJoinFilter(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
addPrimitiveColumn(String, Type, String) - Method in class org.apache.hive.service.cli.TableSchema
 
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
 
addProjectedRowToBatchFrom(Object, StructObjectInspector, int, VectorizedRowBatch, DataOutputBuffer) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Add only the projected column of a regular row to the specified vectorized row batch
addProjectionColumn(String, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
addPruningPred(Map<TableScanOperator, ExprNodeDesc>, TableScanOperator, ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.FilterPruner
Add pruning predicate.
addPruningPred(Map<TableScanOperator, Map<String, ExprNodeDesc>>, TableScanOperator, ExprNodeDesc, Partition) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.FilterPruner
Add pruning predicate.
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.
addQuery(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Adds a new query to the execution list.
addRedirects(Server) - Method in class org.apache.hive.hcatalog.templeton.Main
 
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.
addRole(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addRole(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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.FlatRowContainer
 
addRow(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
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(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
addRow(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
addRow(Object) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Add a row to the ORC file.
addRow(Object) - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
addRow(Object[]) - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
addRow(Object[]) - Method in class org.apache.hive.service.cli.RowBasedSet
 
addRow(Object[]) - Method in interface org.apache.hive.service.cli.RowSet
 
addRowToBatch(Object, StructObjectInspector, int, VectorizedRowBatch, DataOutputBuffer) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Iterates through all 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
addRowToBatchFrom(Object, StructObjectInspector, int, 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 from a given offset
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
 
addService(Service) - Method in class org.apache.hive.service.CompositeService
 
addServiceToToken(String, String) - Static method in class org.apache.hadoop.hive.shims.Utils
Add a given service to delegation token string.
addShutdownHook(Runnable, int) - Static method in class org.apache.hive.common.util.ShutdownHookManager
Adds a shutdownHook with a priority, the higher the priority the earlier will run.
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.
addSortCols(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
addSpecialCasesParametersForHCatLoader(Configuration, HCatTableInfo) - Static method in class org.apache.hive.hcatalog.mapreduce.SpecialCases
Method to do any storage-handler specific special casing while instantiating a HCatLoader
addSpecialCasesParametersToOutputJobProperties(Map<String, String>, OutputJobInfo, Class<? extends OutputFormat>) - Static method in class org.apache.hive.hcatalog.mapreduce.SpecialCases
Method to do any file-format specific special casing while instantiating a storage handler to write.
addStatistics(OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addStatistics(int, OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addStatistics(OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addStatistics(int, OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
addStatisticsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
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.
addStreams(OrcProto.Stream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addStreams(int, OrcProto.Stream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addStreams(OrcProto.Stream.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addStreams(int, OrcProto.Stream.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addStreamsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addStreamsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
addString(String) - Method in class org.apache.hive.common.util.BloomFilter
 
addStringColumn(String, String) - Method in class org.apache.hive.service.cli.TableSchema
 
addStripes(OrcProto.StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripes(int, OrcProto.StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripes(OrcProto.StripeInformation.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripes(int, OrcProto.StripeInformation.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripesBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripesBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
addStripeStats(OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addStripeStats(int, OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addStripeStats(OrcProto.StripeStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addStripeStats(int, OrcProto.StripeStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addStripeStatsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addStripeStatsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
addSubtypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
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
 
addToAborted(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
addToAdjacencyList(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
addToAllReduceSinkOperators(ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
addToBucketCols(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToChildren(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
addToClassPath(ClassLoader, String[]) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Add new elements to the classpath.
addToClassPath(ClassLoader, String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Add new elements to the classpath.
addToClassPath(String[], Configuration, File) - Static method in class org.apache.hive.spark.client.SparkClientUtilities
Add new elements to the classpath.
addToColNames(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
addToColNames(String) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
addToCols(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToColStats(ColumnStatisticsObj) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
addToColStats(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
addToColumns(TColumn) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
addToColumns(TColumnDesc) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
addToColumnStats(List<ColStatistics>) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
addToColVals(TColumnValue) - Method in class org.apache.hive.service.cli.thrift.TRow
 
addToCompacts(ShowCompactResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
addToComponent(LockComponent) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
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(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
addToEstimator(HiveDecimal) - 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(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
addToEstimatorPCSA(HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
addToEstimatorPCSA(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.StringNumDistinctValueEstimator
 
addToEvents(NotificationEvent) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
addToField3(InnerStruct) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
addToFields(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
addToFieldSchemas(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
addToFilesAdded(String) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
addToInfoMessages(String) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
addToken(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addToken(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addToken(DelegationTokenIdentifier, AbstractDelegationTokenSecretManager.DelegationTokenInformation) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
addToken(DelegationTokenIdentifier, AbstractDelegationTokenSecretManager.DelegationTokenInformation) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Add token.
addToken(DelegationTokenIdentifier, AbstractDelegationTokenSecretManager.DelegationTokenInformation) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
addToken(DelegationTokenIdentifier, AbstractDelegationTokenSecretManager.DelegationTokenInformation) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
addTokenFromUserToJobConf(UserGroupInformation, JobConf) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Extract the appropriate Token for Accumulo from the provided user and add it to the JobConf's credentials.
addToLint(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
addToLintString(IntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
addToLocks(ShowLocksResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
addToLString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
addToMy_enumlist(MyEnum) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToMy_enumset(MyEnum) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToMy_stringlist(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToMy_stringset(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToMy_structlist(MiniStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToMy_structset(MiniStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
addToNames(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
addToNew_parts(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
addToNew_parts(PartitionSpec) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
addToNew_parts(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
addToNosuch(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
addToNumRows(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
addToOpen_txns(TxnInfo) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
addToOpen_txns(long) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
addToOperatorList(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
addToPartitionKeys(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
addToPartitionnames(String) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
addToPartitions(Partition) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
addToPartitions(Partition) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
addToPartitions(Partition) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
addToPartitions(Partition) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
addToPartitions(PartitionWithoutSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
addToPartitionVals(String) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
addToPartNames(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
addToParts(Partition) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
addToPartValues(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
addToPrincipalGrants(RolePrincipalGrant) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
addToPrincipalGrants(RolePrincipalGrant) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
addToPrivileges(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
addToQueries(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
addToResourceUris(ResourceUri) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
addToRestrictList(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
Append comma separated list of config vars to the restrict List
addToRoots(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
addToRootTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
addToRows(TRow) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
addToRunnable(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
addToSIntString(IntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
addToSkewedColNames(String) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
addToSkewedColValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
addToSortCols(Order) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToStageList(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
addToStat(String, long) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
addToStatsObj(ColumnStatisticsObj) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
addToSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
addToSuccess(PartitionSpec) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
addToSuccess(PartitionSpec) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
addToSuccess(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
addToSuccess(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
addToSuccess(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
addToTableStats(ColumnStatisticsObj) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
addToTableTypes(String) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
addToTaskList(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
addToTbl_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
addToTxn_ids(long) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
addToTypes(TTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
addToUDFLoaders(ClassLoader) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
addToValues(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
addToValues(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
addToValues(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
addToValues(boolean) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
addToValues(byte) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
addToValues(double) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
addToValues(short) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
addToValues(int) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
addToValues(long) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
addToValues(String) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
addTran(SparkTran) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
addTTDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addTypes(OrcProto.Type) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addTypes(int, OrcProto.Type) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addTypes(OrcProto.Type.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addTypes(int, OrcProto.Type.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addTypesBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addTypesBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
addUnionOperators(Collection<UnionOperator>) - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
addUserHomeDirectoryIfApplicable(String, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
addUserMetadata(String, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Add arbitrary meta-data to the ORC file.
addUserMetadata(String, ByteBuffer) - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
addValue(Type, Object) - Method in class org.apache.hive.service.cli.Column
 
addValueFromDictionary(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
addValueFromDictionary(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
addVersion(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
addVirtualCols(List<VirtualColumn>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
addWalked(ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
addWalkedAll(Collection<ReduceSinkOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
addWar(String, String) - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
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
 
addWrapper(String[]) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
Wrap the script in a wrapper that allows admins to control.
Adjacency - Class in org.apache.hadoop.hive.ql.plan.api
 
Adjacency() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
Adjacency(String, List<String>, AdjacencyType) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
Adjacency(Adjacency) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
Performs a deep copy on other.
Adjacency._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AdjacencyType - Enum in org.apache.hadoop.hive.ql.plan.api
 
adjustArraySize(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Adjust the size of arrays: keyStart, keyLength valueStart, valueLength keyInited, keyIsNull valueInited, valueIsNull.
adjustBeginLineColumn(int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
adjustNumReducers(int) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
ADMIN - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
adminOptionFor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
afterLast() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
afterRun() - Method in class org.apache.hive.service.cli.operation.Operation
Invoked after runInternal(), even if an exception is thrown in runInternal().
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.gen.VectorUDAFAvgDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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.gen.VectorUDAFAvgDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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.hbase.HBaseStatsAggregator
Aggregates temporary stats from HBase;
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.CounterStatsAggregatorSpark
 
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).
AggregateStatsCache - Class in org.apache.hadoop.hive.metastore
 
AggregateStatsCache.AggrColStats - Class in org.apache.hadoop.hive.metastore
 
AggregateStatsCache.AggrColStats(long, BloomFilter, ColumnStatisticsObj) - Constructor for class org.apache.hadoop.hive.metastore.AggregateStatsCache.AggrColStats
 
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
 
AggrStats - Class in org.apache.hadoop.hive.metastore.api
 
AggrStats() - Constructor for class org.apache.hadoop.hive.metastore.api.AggrStats
 
AggrStats(List<ColumnStatisticsObj>, long) - Constructor for class org.apache.hadoop.hive.metastore.api.AggrStats
 
AggrStats(AggrStats) - Constructor for class org.apache.hadoop.hive.metastore.api.AggrStats
Performs a deep copy on other.
AggrStats._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
aggrTypes - Static variable in interface org.apache.hadoop.hive.metastore.IExtrapolatePartStatus
 
AINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
aliasFilterTags - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
On filterTags ANDed value of all filter tags in current join group if any of values passes on outer join alias (which makes zero for the tag alias), it means there exists a pair for it and safely regarded as a inner join for example, with table a, b something like, a = 100, 10 | 100, 20 | 100, 30 b = 100, 10 | 100, 20 | 100, 30 the query "a FO b ON a.k=b.k AND a.v>10 AND b.v>30" makes filter map 0(a) = [1(b),1] : a.v>10 1(b) = [0(a),1] : b.v>30 for filtered rows in a (100,10) create a-NULL for filtered rows in b (100,10) (100,20) (100,30) create NULL-b with 0(a) = [1(b),1] : a.v>10 100, 10 = 00000010 (filtered) 100, 20 = 00000000 (valid) 100, 30 = 00000000 (valid) ------------------------- sum = 00000000 : for valid rows in b, there is at least one pair in a with 1(b) = [0(a),1] : b.v>30 100, 10 = 00000001 (filtered) 100, 20 = 00000001 (filtered) 100, 30 = 00000001 (filtered) ------------------------- sum = 00000001 : for valid rows in a (100,20) (100,30), there is no pair in b result : 100, 10 : N, N N, N : 100, 10 N, N : 100, 20 N, N : 100, 30 100, 20 : N, N 100, 30 : N, N
aliasList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
aliasList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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
 
all(String) - Method in class org.apache.hive.beeline.Commands
 
allFile - Variable in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
allInitializedParentsAreClosed() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
allInitializedParentsAreClosed() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
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
 
allMatchs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
allMatchs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
allMatchs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
allMatchs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
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.
allocateColumnVector(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
 
allocateKeyWrapper() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
 
allocatePartitionDescMap() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
allocateScratchColumn(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
allowColumnName(String) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Adds a column name to the set of column names allowed.
allowEventReplacementInto(Partition) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Determines if a current replication event specification is allowed to replicate-replace-into a given partition
allowEventReplacementInto(Table) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Determines if a current replication event specification is allowed to replicate-replace-into a given table
allowEventReplacementInto() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Returns a predicate filter to filter an Iterable to return all partitions that the current replication event specification is allowed to replicate-replace-into
allowQuotedId() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
allowReplacement(String, String) - Static method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
allowReplacementInto(Partition) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Determines if a current replication object(current state of dump) is allowed to replicate-replace-into a given partition
allowReplacementInto(Table) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Determines if a current replication object(current state of dump) is allowed to replicate-replace-into a given table
allParentsDispatched(Node) - Method in class org.apache.hadoop.hive.ql.lib.ForwardWalker
 
allProceduresAreCallable() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
allTablesAreSelectable() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
AlreadyExistsException - Exception in org.apache.hadoop.hive.metastore.api
 
AlreadyExistsException() - Constructor for exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
AlreadyExistsException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
AlreadyExistsException(AlreadyExistsException) - Constructor for exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
Performs a deep copy on other.
AlreadyExistsException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
alter_database(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_database(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_database(String, Database) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_function(String, String, Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_function_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_function(String, String, Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_function_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_function(String, String, Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_function(String, String, Function) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_function(String, String, Function) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_index(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_index(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_index(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_index(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
alter_partition(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_partition(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_partition(String, String, Partition) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_partition(String, String, Partition) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
updates a partition to new partition
alter_partition_with_environment_context(String, String, Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_partition_with_environment_context(String, String, Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_partition_with_environment_context(String, String, Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_partition_with_environment_context(String, String, Partition, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_partition_with_environment_context(String, String, Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_partitions(String, String, List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partitions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_partitions(String, String, List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partitions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_partitions(String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_partitions(String, String, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_partitions(String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_partitions(String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_partitions(String, String, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
updates a list of partitions
alter_table(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_table(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_table(String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_table(String, String, Table, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_table(String, String, Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_table(String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alter_table(String, String, Table, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alter_table(String, String, Table, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
alter_table(String, String, Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
alter_table_with_cascade(String, String, Table, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_table_with_cascade(String, String, Table, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_table_with_cascade(String, String, Table, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_table_with_cascade(String, String, Table, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_table_with_cascade(String, String, Table, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_table_with_environment_context(String, String, Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_table_with_environment_context(String, String, Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_table_with_environment_context(String, String, Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_table_with_environment_context(String, String, Table, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_table_with_environment_context(String, String, Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alterDatabase(String, Database) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Alter the database object in metastore.
alterDatabase(String, Database) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
alterDatabaseStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterDatabaseSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterDatabaseSuffixSetOwner() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterFunction(String, String, Function) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alterFunction(String, String, Function) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alterFunction(String, String, Function) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterFunction(String, String, Function) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Alter function based on new function specs.
alterFunction(String, String, Function) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
AlterHandler - Interface in org.apache.hadoop.hive.metastore
Interface for Alter Table and Alter Partition code
alterIndex(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterIndex(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterIndex(String, String, Index) - 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.
AlterIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
AlterIndexEvent(Index, Index, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AlterIndexEvent
 
alterIndexStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterOutputOIForStreaming(PTFDesc) - Static method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
alterPartition(RawStore, Warehouse, String, String, List<String>, Partition) - Method in interface org.apache.hadoop.hive.metastore.AlterHandler
handles alter partition
alterPartition(RawStore, Warehouse, String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
alterPartition(String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterPartition(String, String, List<String>, Partition) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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.
AlterPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
AlterPartitionEvent(Partition, Partition, Table, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AlterPartitionEvent
 
AlterPartitionMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a table is Altered.
AlterPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.AlterPartitionMessage
 
AlterPartitionReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
AlterPartitionReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.AlterPartitionReplicationTask
 
alterPartitions(RawStore, Warehouse, String, String, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.AlterHandler
handles alter partitions
alterPartitions(RawStore, Warehouse, String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
alterPartitions(String, String, List<List<String>>, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterPartitions(String, String, List<List<String>>, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterPartitions(String, List<Partition>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing table metadata with the new metadata.
alterProtectMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterProtectModeMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementChangeColPosition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementPartitionKeyType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddPartitionsElement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixArchive() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixBucketNum() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixClusterbySortby() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixCompact() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixDropPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixExchangePartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixFileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixMergeFiles() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixProtectMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRename(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRenameCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRenamePart() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixSerdeProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixSkewedby() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixStatsPart() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixTouch() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixUnArchive() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixUpdateStatsCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterTable(RawStore, Warehouse, String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.AlterHandler
handles alter table
alterTable(RawStore, Warehouse, String, String, Table, boolean) - Method in interface org.apache.hadoop.hive.metastore.AlterHandler
handles alter table, the changes could be cascaded to partitions if applicable
alterTable(RawStore, Warehouse, String, String, Table) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
alterTable(RawStore, Warehouse, String, String, Table, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
alterTable(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterTable(String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterTable(String, Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing table metadata with the new metadata.
alterTable(String, Table, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
AlterTableAlterPartDesc - Class in org.apache.hadoop.hive.ql.plan
 
AlterTableAlterPartDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
AlterTableAlterPartDesc(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, HashMap<String, String>, String, String, String, String, boolean, String, boolean) - 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, HashMap<String, String>, List<FieldSchema>, AlterTableDesc.AlterTableTypes, boolean) - 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
 
AlterTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
AlterTableEvent(Table, Table, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.AlterTableEvent
 
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
 
AlterTableMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a table is Altered.
AlterTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.AlterTableMessage
 
AlterTablePartMergeFilesDesc - Class in org.apache.hadoop.hive.ql.parse
 
AlterTablePartMergeFilesDesc(String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
AlterTableReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
AlterTableReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.AlterTableReplicationTask
 
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, Map<String, String>, AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
AlterTableSimpleDesc(String, LinkedHashMap<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
Constructor for ALTER TABLE ...
alterTableStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterTableTypesWithPartialSpec - Static variable in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
alterTblPartitionStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterTblPartitionStatementSuffixSkewedLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterViewStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterViewSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
amMemoryMb() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
analyzeDDLSkewedValues(List<List<String>>, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Handle skewed values in DDL.
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.CalcitePlanner
 
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.ExplainSQRewriteSemanticAnalyzer
 
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
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.UpdateDeleteSemanticAnalyzer
 
analyzeJoinForPKFK(Join) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
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
 
analyzeRewrite - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
analyzeSkewedTablDDLColNames(List<String>, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Analyze list bucket column names
analyzeStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
analyzeStoredAdDirs(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
process stored as directories
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
andExpression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
annotateMapWork(GenSparkProcContext, MapWork, SMBMapJoinOperator, TableScanOperator, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinFactory
Annotate MapWork, input is a SMBJoinOp that is part of a MapWork, and its root TS operator.
annotateMapWork(GenSparkProcContext) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
Fill MapWork with 'local' work and bucket information for SMB Join.
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
 
AnnotationUtils - Class in org.apache.hive.common.util
 
AnnotationUtils() - Constructor for class org.apache.hive.common.util.AnnotationUtils
 
AnonymousAuthenticationProviderImpl - Class in org.apache.hive.service.auth
This authentication provider allows any combination of username and password.
AnonymousAuthenticationProviderImpl() - Constructor for class org.apache.hive.service.auth.AnonymousAuthenticationProviderImpl
 
ansiSqlArithmetic - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseArithmetic
 
ansiSqlArithmetic - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
appConf - Variable in class org.apache.hive.hcatalog.templeton.TempletonDelegator
 
appConf - Variable in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
appConf - Variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
AppConfig - Class in org.apache.hive.hcatalog.templeton
The configuration for Templeton.
AppConfig() - Constructor for class org.apache.hive.hcatalog.templeton.AppConfig
 
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
append(String) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
append(Object) - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
append(Object) - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
append(Writable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
Append a row of values.
append(HCatFieldSchema) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
append_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
append_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
append_partition_with_environment_context(String, String, List<String>, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition_with_environment_context(String, String, List<String>, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition_with_environment_context(String, String, List<String>, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition_with_environment_context(String, String, List<String>, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition_with_environment_context(String, String, List<String>, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
appendCauseMessage() - Method in enum org.apache.hive.hcatalog.common.ErrorType
Whether the cause of the exception should be added to the error message.
appendPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, List<String>, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
appendPartition(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
appendPartitionByName(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartitionByName(String, String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendReadColumnIDs(Configuration, List<Integer>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Deprecated.
for backwards compatibility with <= 0.12, use appendReadColumns
appendReadColumns(Configuration, List<Integer>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Appends read columns' ids (start from zero).
appendReadColumns(Configuration, List<Integer>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
appendReadColumns(StringBuilder, StringBuilder, List<Integer>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
appendStripe(byte[], int, int, StripeInformation, OrcProto.StripeStatistics) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Fast stripe append to ORC file.
appendStripe(byte[], int, int, StripeInformation, OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
appendUserMetadata(List<OrcProto.UserMetadataItem>) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
When fast stripe append is used for merging ORC stripes, after appending the last stripe from a file, this interface must be used to merge any user metadata.
appendUserMetadata(List<OrcProto.UserMetadataItem>) - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
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(Mappings.TargetMapping) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
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.HiveV1Authorizer
 
applyAuthorizationConfigPolicy(HiveConf) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
applyAuthorizationConfigPolicy(HiveConf) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
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.
applyCorrelation(ParseContext, CorrelationOptimizer.CorrelationNodeProcCtx, IntraQueryCorrelation) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.QueryPlanTreeTransformation
Based on the correlation, we transform the query plan tree (operator tree).
applyOffset(long, Timestamp) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
AppMasterEventDesc - Class in org.apache.hadoop.hive.ql.plan
 
AppMasterEventDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
AppMasterEventOperator - Class in org.apache.hadoop.hive.ql.exec
AppMasterEventOperator sends any rows it receives to the Tez AM.
AppMasterEventOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
AppMasterEventProcessor - Class in org.apache.hadoop.hive.ql.parse
FileSinkProcessor is a simple rule to remember seen unions for later processing.
AppMasterEventProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.AppMasterEventProcessor
 
ArchiveDesc - Class in org.apache.hadoop.hive.ql.plan
ArchiveDesc.
ArchiveDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ArchiveDesc
 
ARCHIVES - Static variable in class org.apache.hive.hcatalog.templeton.TempletonDelegator
http://hadoop.apache.org/docs/r1.0.4/commands_manual.html#Generic+Options
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.metastore.MetaStoreUtils
 
ARCHIVING_LEVEL - Static variable in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
 
areAllParentsInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Operator
checks whether all parent operators are initialized or not.
areAllTrue(boolean[]) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
areEqual(Object[], Object[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ListObjectsEqualComparer
ol0, ol1 should have equal or less number of elements than objectinspectors passed in constructor.
arePathsOnSameEncryptionZone(Path, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
arePathsOnSameEncryptionZone(Path, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
Checks if two HDFS paths are on the same encrypted or unencrypted zone.
arePathsOnSameEncryptionZone(Path, Path) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
areStatsUptoDate(Map<String, String>) - Static method in class org.apache.hadoop.hive.common.StatsSetupConst
 
arg0Type(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
argumentOIs - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
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
 
arrayEntry(TArrayTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
arrayList() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
arraysEquals(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
arrayToString(String[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given an array of strings, return a comma-separated list of its elements.
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
 
asLong() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Returns the value of this object as long, throwing error if the value exceeds long.
assertNoDeniedPermissions(HivePrincipal, HiveOperationType, List<String>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
 
assertNotNull(Object, String, Logger) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
assertState(OperationState) - Method in class org.apache.hive.service.cli.operation.Operation
 
assertSupportsTableSnapshots() - Static method in class org.apache.hadoop.hive.hbase.HBaseTableSnapshotInputFormatUtil
Return true when the HBase runtime supports HiveHBaseTableSnapshotInputFormat.
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToCharViaLongToChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToString
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToString
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToString
 
assign(BytesColumnVector, int, byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToVarChar
 
assign(BytesColumnVector, int, byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
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, HiveDecimalWritable) - 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
 
assignRow(int, Object[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
assignRowColumn(int, int, Object) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
assignSlot(int, byte[], int, int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMap
 
assignSlot(int, byte[], int, int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMultiSet
 
assignSlot(int, byte[], int, int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashSet
 
assignSlot(int, byte[], int, int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
assignSlot(int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
assignSlot(int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet
 
assignSlot(int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet
 
assignSlot(int, long, boolean, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
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.calcite.translator
 
ASTERISK - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
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
 
ASTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
Async() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
atomExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
atomExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
ATSHook - Class in org.apache.hadoop.hive.ql.hooks
ATSHook sends query + plan info to Yarn App Timeline Server.
ATSHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.ATSHook
 
Attr - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
Attr(String, String) - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.Attr
 
AUDIT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
auditLog - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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.
AUTH_COOKIE - Static variable in class org.apache.hive.service.cli.thrift.ThriftHttpServlet
 
Authenticate(String, String) - Method in class org.apache.hive.service.auth.AnonymousAuthenticationProviderImpl
 
Authenticate(String, String) - Method in class org.apache.hive.service.auth.CustomAuthenticationProviderImpl
 
Authenticate(String, String) - Method in class org.apache.hive.service.auth.LdapAuthenticationProviderImpl
 
Authenticate(String, String) - Method in class org.apache.hive.service.auth.PamAuthenticationProviderImpl
 
Authenticate(String, String) - Method in interface org.apache.hive.service.auth.PasswdAuthenticationProvider
The Authenticate method is called by the HiveServer2 authentication layer to authenticate users for their requests.
AuthenticationProviderFactory - Class in org.apache.hive.service.auth
This class helps select a PasswdAuthenticationProvider for a given AuthMethod.
AuthenticationProviderFactory.AuthMethods - Enum in org.apache.hive.service.auth
 
authenticator - Variable in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
AUTHORIZATION - Static variable in class org.apache.hive.service.auth.HttpAuthUtils
 
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
 
AuthorizationFactory - Class in org.apache.hadoop.hive.ql.security.authorization
 
AuthorizationFactory() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationFactory
 
AuthorizationFactory.AuthorizationExceptionHandler - Interface in org.apache.hadoop.hive.ql.security.authorization
 
AuthorizationFactory.DefaultAuthorizationExceptionHandler - Class in org.apache.hadoop.hive.ql.security.authorization
 
AuthorizationFactory.DefaultAuthorizationExceptionHandler() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationFactory.DefaultAuthorizationExceptionHandler
 
AuthorizationMetaStoreFilterHook - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Metastore filter hook for filtering out the list of objects that the current authorization implementation does not allow user to see
AuthorizationMetaStoreFilterHook(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.AuthorizationMetaStoreFilterHook
 
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
 
AUTHORIZATIONS_KEY - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
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(Table, Iterable<Partition>, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveMultiPartitionAuthorizationProviderBase
Authorization method for partition sets.
authorize(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
authorize(Database, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
authorize(Table, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
authorize(Partition, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
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.
authorize(Privilege[], Privilege[]) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
authorize(Database, Privilege) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
authorize(Table, Privilege) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
authorize(Partition, Privilege) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
authorizeAndGetRevokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, boolean, IMetaStoreClient, String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RevokePrivAuthUtils
 
authorizeAuthorizationApiInvocation() - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveMetastoreAuthorizationProvider
 
authorizeAuthorizationApiInvocation() - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveMetastoreAuthorizationProvider
Authorize metastore authorization api call.
authorizeAuthorizationApiInvocation() - Method in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
authorizeAuthorizationApiInvocation() - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorizeDDL(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
Checks for the given rootTasks, and calls authorizeDDLWork() for each DDLWork to be authorized.
authorizeDDLWork(HiveSemanticAnalyzerHookContext, Hive, DDLWork) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzer
 
authorizeDDLWork(HiveSemanticAnalyzerHookContext, Hive, DDLWork) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
Authorized the given DDLWork.
authorizeMetaGets(HiveOperationType, List<HivePrivilegeObject>) - Method in class org.apache.hive.service.cli.operation.MetadataOperation
 
authorizeMetaGets(HiveOperationType, List<HivePrivilegeObject>, String) - Method in class org.apache.hive.service.cli.operation.MetadataOperation
 
authorizePrivileges(PrincipalPrivilegeSet, Privilege[], boolean[], Privilege[], boolean[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorizeTable(Hive, String, Privilege) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
authorizeUserPriv(Privilege[], boolean[], Privilege[], boolean[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
autocommit(String) - Method in class org.apache.hive.beeline.Commands
 
autoCommitFailureClosesAllResultSets() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
autoDelete - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
autoDelete - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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.
autoRebuild() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
auxJars - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
available() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
available() - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
available() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
averageColumnSizes(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSize
 
averageColumnSizes(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSize
 
averageTypeValueSize(RelDataType) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSize
 
AvgPartitionSizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
AvgPartitionSizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.AvgPartitionSizeBasedBigTableSelectorForAutoSMJ
 
AVRO - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
AVRO_INT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_LONG_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_PROP_LOGICAL_TYPE - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_PROP_MAX_LENGTH - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_PROP_PRECISION - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_PROP_SCALE - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AVRO_SERDE_SCHEMA - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
AVRO_SERIALIZATION_TYPE - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
AVRO_STRING_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
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
 
AVROFILE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
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
 
AvroGenericRecordWritable - Class in org.apache.hadoop.hive.serde2.avro
Wrapper around an Avro GenericRecord.
AvroGenericRecordWritable() - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
AvroGenericRecordWritable(GenericRecord) - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
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
 
AvroHBaseValueFactory - Class in org.apache.hadoop.hive.hbase.struct
Avro specific implementation of the HBaseValueFactory
AvroHBaseValueFactory(int, Schema) - Constructor for class org.apache.hadoop.hive.hbase.struct.AvroHBaseValueFactory
Constructor
AvroLazyObjectInspector - Class in org.apache.hadoop.hive.serde2.avro
Lazy objectinspector for avro serialization
AvroLazyObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, Text, boolean, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
Deprecated.
AvroLazyObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
 
AvroObjectInspectorException - Exception in org.apache.hadoop.hive.serde2.avro
Exception for the AvroLazyObjectInspector
AvroObjectInspectorException() - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorException
 
AvroObjectInspectorException(String) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorException
 
AvroObjectInspectorException(Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorException
 
AvroObjectInspectorException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorException
 
AvroObjectInspectorGenerator - Class in org.apache.hadoop.hive.serde2.avro
An AvroObjectInspectorGenerator takes an Avro schema and creates the three data structures Hive needs to work with Avro-encoded data: * A list of the schema field names * A list of those fields equivalent types in Hive * An ObjectInspector capable of working with an instance of that datum.
AvroObjectInspectorGenerator(Schema) - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
AvroSchemaRetriever - Class in org.apache.hadoop.hive.serde2.avro
Retrieves the avro schema from the given source.
AvroSchemaRetriever() - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroSchemaRetriever
 
AvroSerDe - Class in org.apache.hadoop.hive.serde2.avro
Read or write Avro data from Hive.
AvroSerDe() - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
AvroSerdeException - Exception in org.apache.hadoop.hive.serde2.avro
 
AvroSerdeException() - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroSerdeException
 
AvroSerdeException(String) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroSerdeException
 
AvroSerdeException(Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroSerdeException
 
AvroSerdeException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.avro.AvroSerdeException
 
AvroSerdeUtils - Class in org.apache.hadoop.hive.serde2.avro
Utilities useful only to the AvroSerde itself.
AvroSerdeUtils() - Constructor for class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
AvroSerdeUtils.AvroTableProperties - Enum in org.apache.hadoop.hive.serde2.avro
Enum container for all avro table properties.
AvroStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
AvroStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.AvroStorageFormatDescriptor
 

B

backgroundHandle - Variable in class org.apache.hive.service.cli.operation.Operation
 
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(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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.exec.AbstractFileMergeOperator
 
BACKUP_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
backupChildrenTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
backupOutputPath(FileSystem, Path, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
backupTask - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
BadParam - Exception in org.apache.hive.hcatalog.templeton
Missing required or badly configured paramater.
BadParam(String) - Constructor for exception org.apache.hive.hcatalog.templeton.BadParam
 
BadSchemaException - Exception in org.apache.hadoop.hive.serde2.avro
 
BadSchemaException() - Constructor for exception org.apache.hadoop.hive.serde2.avro.BadSchemaException
 
Base64TextInputFormat - Class in org.apache.hadoop.hive.contrib.fileformat.base64
FileInputFormat for base64 encoded text files.
Base64TextInputFormat() - Constructor for class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat
 
Base64TextInputFormat.Base64LineRecordReader - Class in org.apache.hadoop.hive.contrib.fileformat.base64
Base64LineRecordReader.
Base64TextInputFormat.Base64LineRecordReader(LineRecordReader) - Constructor for class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
Base64TextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.contrib.fileformat.base64
FileOutputFormat for base64 encoded text files.
Base64TextOutputFormat() - Constructor for class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat
 
Base64TextOutputFormat.Base64RecordWriter - Class in org.apache.hadoop.hive.contrib.fileformat.base64
Base64RecordWriter.
Base64TextOutputFormat.Base64RecordWriter(FileSinkOperator.RecordWriter) - Constructor for class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat.Base64RecordWriter
 
BASE_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
BaseCharTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
 
BaseCharTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
BaseCharTypeInfo(String) - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
BaseCharTypeInfo(String, int) - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
BaseCharUtils - Class in org.apache.hadoop.hive.serde2.typeinfo
 
BaseCharUtils() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.BaseCharUtils
 
baseFileFilter - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
baseOI - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
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.AnalyzeRewriteContext - Class in org.apache.hadoop.hive.ql.parse
 
BaseSemanticAnalyzer.AnalyzeRewriteContext() - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
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, String, Map<String, String>) - 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
 
BaseStructObjectInspector - Class in org.apache.hadoop.hive.serde2
 
BaseStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
BaseStructObjectInspector(List<String>, List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
Call ObjectInspectorFactory.getLazySimpleStructObjectInspector instead.
BaseStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Constructor for class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
BaseStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2
 
BaseStructObjectInspector.MyField(int, String, ObjectInspector, String) - Constructor for class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
BaseStructObjectInspector.MyField(int, StructField) - Constructor for class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
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
 
BASIC - Static variable in class org.apache.hive.service.auth.HttpAuthUtils
 
batch(String) - Method in class org.apache.hive.beeline.Commands
 
batchCounter - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
batchIndexToResult - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
batchSize - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
bDynParts - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
BeeLine - Class in org.apache.hive.beeline
A console SQL shell with command completion.
BeeLine() - Constructor for class org.apache.hive.beeline.BeeLine
 
BeeLine.BeelineParser - Class in org.apache.hive.beeline
 
BeeLine.BeelineParser() - Constructor for class org.apache.hive.beeline.BeeLine.BeelineParser
 
BEELINE_DEFAULT_JDBC_DRIVER - Static variable in class org.apache.hive.beeline.BeeLine
 
BEELINE_DEFAULT_JDBC_URL - Static variable in class org.apache.hive.beeline.BeeLine
 
BeeLineSignalHandler - Interface in org.apache.hive.beeline
BeeLineSignalHandler.
beforeFirst() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
beforeFirst() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
Moves the cursor before the first row of the resultset.
beforeRun() - Method in class org.apache.hive.service.cli.operation.Operation
Invoked before runInternal().
begin(String[], InputStream) - Method in class org.apache.hive.beeline.BeeLine
Start accepting input from stdin, and dispatch it to the appropriate CommandHandler until the global variable exit is true.
beginColumn - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginLine - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginNextTransaction() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Activate the next available transaction in the current transaction batch
BeginToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
beginTreeNode(ExpressionTree.TreeNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
BETWEEN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
BETWEEN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
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.
betweenExpression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
bigDecimalValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
BIGINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
BigintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
BigintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BigintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
BigintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
BigintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
bigTableByteColumnVectorColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableFilterExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableFilterExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
bigTableKeyColumnMap - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableKeyExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableKeyTypeNames - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableOuterKeyMapping - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableOuterKeyOutputVectorColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableRetainedMapping - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableRetainedVectorCopy - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
BigTableSelectorForAutoSMJ - Interface in org.apache.hadoop.hive.ql.optimizer
 
bigTableValueColumnMap - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableValueExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableValueExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
bigTableValueTypeNames - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
bigTableVectorCopyOuterKeys - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
BINARY - Static variable in class org.apache.hive.hcatalog.data.DataType
 
BINARY_SORTABLE_LENGTH - Static variable in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
BINARY_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
BINARY_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
BINARY = 8;
BinaryColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for binary columns.
BinaryColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
BinaryColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
BinaryColumnStatsData(long, double, long) - Constructor for class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
BinaryColumnStatsData(BinaryColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
Performs a deep copy on other.
BinaryColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
binaryEvaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
BinaryObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
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
 
BinarySortableDeserializeRead - Class in org.apache.hadoop.hive.serde2.binarysortable.fast
 
BinarySortableDeserializeRead(PrimitiveTypeInfo[]) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
BinarySortableDeserializeRead(PrimitiveTypeInfo[], boolean[]) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
BinarySortableSerDe - Class in org.apache.hadoop.hive.serde2.binarysortable
BinarySortableSerDe can be used to write data in a way that the data can be compared byte-by-byte with the same order.
BinarySortableSerDe() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
BinarySortableSerializeWrite - Class in org.apache.hadoop.hive.serde2.binarysortable.fast
 
BinarySortableSerializeWrite(boolean[]) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
BinarySortableSerializeWrite(int) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
BINARYSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
binaryStats(BinaryColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
binaryTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
binaryTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
binaryVal(TBinaryColumn) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
binaryValue(int) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
binOpExpression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
bis - Variable in class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
bis_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
bitLength(int, int, int, int) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
Returns the minimal number of bits to represent the words.
bitLengthInWord(int) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
Returns the minimal number of bits to represent the given integer value.
bitmapBop(EWAHCompressedBitmap, EWAHCompressedBitmap) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
bitmapBop(EWAHCompressedBitmap, EWAHCompressedBitmap) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapAnd
 
bitmapBop(EWAHCompressedBitmap, EWAHCompressedBitmap) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapOr
 
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
bitmapToWordArray(EWAHCompressedBitmap) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
bitSet - Variable in class org.apache.hive.common.util.BloomFilter
 
BITSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
BitSetCheckedAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
 
BitSetCheckedAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
bitSize() - Method in class org.apache.hive.common.util.BloomFilter.BitSet
Number of bits
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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.
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.
blockSize(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Set the file system block size for the file.
BLOOM_FILTER_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
BLOOM_FILTER = 7;
BloomFilter - Class in org.apache.hive.common.util
BloomFilter is a probabilistic data structure for set membership check.
BloomFilter() - Constructor for class org.apache.hive.common.util.BloomFilter
 
BloomFilter(long) - Constructor for class org.apache.hive.common.util.BloomFilter
 
BloomFilter(long, double) - Constructor for class org.apache.hive.common.util.BloomFilter
 
BloomFilter.BitSet - Class in org.apache.hive.common.util
Bare metal bit set implementation.
BloomFilter.BitSet(long) - Constructor for class org.apache.hive.common.util.BloomFilter.BitSet
 
BloomFilter.BitSet(long[]) - Constructor for class org.apache.hive.common.util.BloomFilter.BitSet
Deserialize long array as bit set.
BLOOMFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
bloomFilterColumns(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Comma separated values of column names for which bloom filter is to be created.
bloomFilterFpp(double) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Specify the false positive probability for bloom filter.
BloomFilterIO - Class in org.apache.hadoop.hive.ql.io.filters
 
BloomFilterIO(long) - Constructor for class org.apache.hadoop.hive.ql.io.filters.BloomFilterIO
 
BloomFilterIO(long, double) - Constructor for class org.apache.hadoop.hive.ql.io.filters.BloomFilterIO
 
BloomFilterIO(OrcProto.BloomFilter) - Constructor for class org.apache.hadoop.hive.ql.io.filters.BloomFilterIO
Initializes the BloomFilter from the given Orc BloomFilter
body() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
boi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
boi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
BOOLEAN - Static variable in class org.apache.hive.hcatalog.data.DataType
 
BOOLEAN_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
BOOLEAN_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
BOOLEAN = 0;
BooleanColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for boolean columns.
BooleanColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
BooleanColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
BooleanColumnStatsData(long, long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
BooleanColumnStatsData(BooleanColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
Performs a deep copy on other.
BooleanColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BooleanObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A BooleanObjectInspector inspects an Object representing a Boolean.
booleanStats(BooleanColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
booleanTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
booleanTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
booleanValue() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
booleanValue() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
boolVal(TBoolColumn) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
boolVal(TBoolValue) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
bos - Variable in class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
bos_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
BoundaryDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
BoundaryDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
BreakableService - Class in org.apache.hive.service
This is a service that can be configured to break on any of the lifecycle events, so test the failure handling of other parts of the service infrastructure.
BreakableService() - Constructor for class org.apache.hive.service.BreakableService
 
BreakableService(boolean, boolean, boolean) - Constructor for class org.apache.hive.service.BreakableService
 
BreakableService.BrokenLifecycleEvent - Exception in org.apache.hive.service
The exception explicitly raised on a failure
brief(String) - Method in class org.apache.hive.beeline.Commands
 
bucket(int) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
The bucket that is included in this file.
BUCKET_COUNT - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
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_FIELD_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
BUCKET_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
bucketCols(List<String>, int) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
bucketCols(List<String>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for list of bucket columns.
bucketEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
Evaluators for bucketing columns.
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.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
 
bucketMap - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
bucketname - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
bucketNumber - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
bucketowner - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
BUCKETSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
bufcolumn - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
buffer - Variable in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
buffer - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
bufferForExpr() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
bufferForExpr() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
bufferForGuid() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
bufferForMy_binary() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
bufferForNulls() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
bufferForSecret() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
bufferForUnscaled() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
bufferRangeHasExtraDataWarned() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
bufferRangeHasExtraDataWarned() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
bufferRangeHasExtraDataWarned() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
bufferRangeHasExtraDataWarned() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
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.
bufferSize - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
bufferSize - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The size of the internal buffer to use.
BufferSizeKey - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
bufline - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
bufpos - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
build() - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Get the constructed lock component.
build() - Method in class org.apache.hadoop.hive.metastore.LockRequestBuilder
Get the constructed LockRequest.
build() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticsBuilder
 
build() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.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
 
build() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
 
build() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
build() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc.Builder
Builds the HCatAddPartitionDesc.
build() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc.Builder
Builds the create database descriptor.
build() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Builds the HCatCreateTableDesc.
build() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.CollectionBuilder
 
build() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.HCatSchemaBuilder
 
build() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.MapBuilder
 
build() - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
build() - Method in class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
build() - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Turn the map back to response object.
build() - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
buildAddPartitionMessage(Table, Iterator<Partition>) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildAddPartitionMessage(Table, Iterator<Partition>) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for AddPartitionMessage.
buildAlterPartitionMessage(Table, Partition, Partition) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildAlterPartitionMessage(Table, Partition, Partition) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for building AlterPartitionMessage
buildAlterTableMessage(Table, Table) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildAlterTableMessage(Table, Table) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for AlterTableMessage.
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.
buildAssigners(VectorizedRowBatch, Writable[]) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
buildAST(SqlOperator, List<ASTNode>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
buildAST(SqlOperator, List<ASTNode>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
Build AST for flattened Associative expressions ('and', 'or').
buildCommand(String, String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Flatten the nested upgrade script into a buffer
buildCreateDatabaseMessage(Database) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildCreateDatabaseMessage(Database) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for CreateDatabaseMessage.
buildCreateTableMessage(Table) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildCreateTableMessage(Table) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for CreateTableMessage.
buildDropDatabaseMessage(Database) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildDropDatabaseMessage(Database) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for DropDatabaseMessage.
buildDropPartitionMessage(Table, Iterator<Partition>) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildDropPartitionMessage(Table, Iterator<Partition>) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for DropPartitionMessage.
buildDropTableMessage(Table) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildDropTableMessage(Table) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for DropTableMessage.
buildErrorMessage(ErrorType, String, Throwable) - Static method in exception org.apache.hive.hcatalog.common.HCatException
Builds the error message string.
buildExpressionDef(ShapeDetails, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
buildExprNode(ASTNode, TypeCheckCtx) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExpressionParser
 
buildInsertMessage(String, String, Map<String, String>, List<String>) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
buildInsertMessage(String, String, Map<String, String>, List<String>) - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Factory method for building insert message
buildJson() - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Turn the map back to json.
buildMessage(int, Map<String, Object>, String) - Static method in exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
buildObjectAssign(VectorizedRowBatch, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
buildObjectAssign(VectorizedRowBatch, int, PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
buildPartial() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
buildPredicate(PredicateLeaf.Operator, List<Object>, String) - Method in class org.apache.hadoop.hive.ql.io.parquet.FilterPredicateLeafBuilder
Build filter predicate with multiple constants
buildPredict(PredicateLeaf.Operator, Object, String) - Method in class org.apache.hadoop.hive.ql.io.parquet.FilterPredicateLeafBuilder
Build predicate with a single constant
buildResponse() - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Turn the map back to response object.
buildResponse(int) - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Turn the map back to response object.
buildRowResolverForNoop(String, StructObjectInspector, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
buildRowResolverForPTF(String, String, StructObjectInspector, List<String>, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
buildRowResolverForWindowing(WindowTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
BusyException - Exception in org.apache.hive.hcatalog.templeton
Simple "we are busy, try again" exception.
BusyException() - Constructor for exception org.apache.hive.hcatalog.templeton.BusyException
 
byName(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
 
byoi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
byoi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
byPass() - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
BYTE - Static variable in class org.apache.hive.hcatalog.data.DataType
 
BYTE_SIZE - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
Number of bytes to store this object.
BYTE_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
BYTE = 1;
byteArrayCompareRanges(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
ByteArrayRef - Class in org.apache.hadoop.hive.serde2.lazy
ByteArrayRef stores a reference to a byte array.
ByteArrayRef() - Constructor for class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
byteArrayToInt(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to an int starting from the given offset.
byteArrayToLong(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to a long starting from the given offset.
byteArrayToShort(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to a short starting from the given offset.
byteDesc(long) - Static method in class org.apache.hive.common.util.HiveStringUtils
Return an abbreviated English-language desc of the byte length
ByteLengthLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
ByteLengthLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ByteLengthLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
ByteLengthLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
ByteLengthLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
ByteObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A ByteObjectInspector inspects an Object representing a Byte object.
bytes - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
bytes - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadBytesResults
 
bytes - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
bytes - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
bytes - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.StringWrapper
 
BytesBytesMultiHashMap - Class in org.apache.hadoop.hive.ql.exec.persistence
HashMap that maps byte arrays to byte arrays with limited functionality necessary for MapJoin hash tables, with small memory overhead.
BytesBytesMultiHashMap(int, float, int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
BytesBytesMultiHashMap.KvSource - Interface in org.apache.hadoop.hive.ql.exec.persistence
The source of keys and values to put into hashtable; avoids byte copying.
BytesBytesMultiHashMap.Result - Class in org.apache.hadoop.hive.ql.exec.persistence
The result of looking up a key in the multi-hash map.
BytesBytesMultiHashMap.Result() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
 
bytesBytesMultiHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
bytesBytesMultiHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult
 
bytesBytesMultiHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet.HashSetResult
 
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.
bytesRead - Variable in class org.apache.hive.spark.client.metrics.InputMetrics
 
BytesRefArrayWritable - Class in org.apache.hadoop.hive.serde2.columnar
BytesRefArrayWritable holds an array reference to BytesRefWritable, and is able to resize without recreating new array if not necessary.
BytesRefArrayWritable(int) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Constructs an empty array with the specified capacity.
BytesRefArrayWritable() - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Constructs an empty array with a capacity of ten.
BytesRefWritable - Class in org.apache.hadoop.hive.serde2.columnar
BytesRefWritable referenced a section of byte array.
BytesRefWritable() - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a zero-size bytes.
BytesRefWritable(int) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a BytesRefWritable with length bytes.
BytesRefWritable(byte[]) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a BytesRefWritable referenced to the given bytes.
BytesRefWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a BytesRefWritable referenced to one section of the given bytes.
BytesRefWritable(LazyDecompressionCallback, int, int) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a BytesRefWritable referenced to one section of the given bytes.
bytessent - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
ByteStream - Class in org.apache.hadoop.hive.serde2
Extensions to bytearrayinput/output streams.
ByteStream() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream
 
ByteStream.Input - Class in org.apache.hadoop.hive.serde2
Input.
ByteStream.Input() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Input(byte[]) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Input(byte[], int, int) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Output - Class in org.apache.hadoop.hive.serde2
Output.
ByteStream.Output() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Output
 
ByteStream.Output(int) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Output
 
ByteStream.RandomAccessOutput - Interface in org.apache.hadoop.hive.serde2
 
ByteStreamTypedSerDe - Class in org.apache.hadoop.hive.serde2
ByteStreamTypedSerDe.
ByteStreamTypedSerDe(Type) - Constructor for class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
byteToHexString(byte[], int, int) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes
byteToHexString(byte[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
Same as byteToHexString(bytes, 0, bytes.length).
byteTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
byteTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
byteVal(TByteColumn) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
byteVal(TByteValue) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
byteValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
ByteWritable - Class in org.apache.hadoop.hive.ql.exec
Deprecated.
ByteWritable(int) - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
ByteWritable() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
ByteWritable - Class in org.apache.hadoop.hive.serde2.io
ByteWritable.
ByteWritable(byte) - Constructor for class org.apache.hadoop.hive.serde2.io.ByteWritable
 
ByteWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.ByteWritable
 
ByteWritable.Comparator - Class in org.apache.hadoop.hive.ql.exec
Deprecated.
A Comparator optimized for BytesWritable.
ByteWritable.Comparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable.Comparator
Deprecated.
 

C

C - Static variable in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
cacheBaseWork(Configuration, String, BaseWork, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
cachedKeys - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
This two dimensional array holds key data and a corresponding Union object which contains the tag identifying the aggregate expression for distinct columns.
cachedMap - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyMap
cachedMap is reused for different calls to getMap().
cachedObjectInspector - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
cachedValues - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
cacheMapWork(Configuration, MapWork, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
cacheThreadLocalRawStore() - Method in class org.apache.hive.service.server.ThreadWithGarbageCleanup
Cache the ThreadLocal RawStore object.
CachingPrintStream - Class in org.apache.hadoop.hive.common.io
 
CachingPrintStream(OutputStream, boolean, String) - Constructor for class org.apache.hadoop.hive.common.io.CachingPrintStream
 
CachingPrintStream(OutputStream) - Constructor for class org.apache.hadoop.hive.common.io.CachingPrintStream
 
CalcitePlanner - Class in org.apache.hadoop.hive.ql.parse
 
CalcitePlanner(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.CalcitePlanner
 
CalciteSemanticException - Exception in org.apache.hadoop.hive.ql.optimizer.calcite
Exception from SemanticAnalyzer.
CalciteSemanticException() - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException(String) - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException(String, CalciteSemanticException.UnsupportedFeature) - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException(ErrorMsg, String...) - Constructor for exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
CalciteSemanticException.UnsupportedFeature - Enum in org.apache.hadoop.hive.ql.optimizer.calcite
 
calcNumPartitions(long, long, int, int, HybridHashTableConf) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Calculate how many partitions are needed.
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
calculateTableSize(float, int, float, long) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
calendar - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
call(Iterator<Tuple2<BytesWritable, BytesWritable>>) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunction
 
call(Iterator<Tuple2<HiveKey, Iterable<BytesWritable>>>) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunction
 
call(Tuple2<HiveKey, BytesWritable>) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveVoidFunction
 
call(String) - Method in class org.apache.hive.beeline.Commands
 
call(JobContext) - Method in interface org.apache.hive.spark.client.Job
 
call(Object) - Method in class org.apache.hive.spark.client.rpc.Rpc
Send an RPC call to the remote endpoint and returns a future that can be used to monitor the operation.
call(Object, Class<T>) - Method in class org.apache.hive.spark.client.rpc.Rpc
Send an RPC call to the remote endpoint and returns a future that can be used to monitor the operation.
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.
callback - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
CALLBACK_INTERVAL_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
CALLBACK_RETRY_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
CallbackFailedException - Exception in org.apache.hive.hcatalog.templeton
The callback failed when it tried to reach the callback URL.
CallbackFailedException(String) - Constructor for exception org.apache.hive.hcatalog.templeton.CallbackFailedException
 
calLocal - Variable in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
calUtc - Variable in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
camelize(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Convert SOME_STUFF to SomeStuff
canAcceptInputAsStream - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
canAcceptInputAsStream() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
canApplyOnTableScanOperator(TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyProcFactory
 
canBeMerged() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
cancel() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
cancel() - Method in class org.apache.hive.jdbc.HiveStatement
 
cancel() - Method in class org.apache.hive.service.cli.operation.Operation
 
cancel() - Method in class org.apache.hive.service.cli.operation.SQLOperation
 
cancel_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
cancel_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
cancel_delegation_token(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
cancelDelegationToken(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Discard a current delegation token.
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
cancelDelegationToken(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
 
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
cancelDelegationToken(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Cancel delegation token.
cancelDelegationToken(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
cancelDelegationToken(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
cancelDelegationToken(String) - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
cancelDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.CLIService
 
cancelDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.CLIServiceClient
 
cancelDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
cancelDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
cancelDelegationToken(HiveAuthFactory, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
cancelDelegationToken(HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
cancelDelegationToken(HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
CancelDelegationToken(TCancelDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelDelegationToken_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
CancelDelegationToken(TCancelDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelDelegationToken_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
CancelDelegationToken(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
CancelDelegationToken(TCancelDelegationTokenReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
CancelDelegationToken(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
cancelDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
cancelJob() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobRef
 
cancelJob() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobRef
 
cancelJob() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobRef
 
cancelOperation(OperationHandle) - Method in class org.apache.hive.service.cli.CLIService
 
cancelOperation(OperationHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
cancelOperation(OperationHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
cancelOperation(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
cancelOperation(OperationHandle) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
cancelOperation(OperationHandle) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
CancelOperation(TCancelOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelOperation_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
CancelOperation(TCancelOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelOperation_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
CancelOperation(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
CancelOperation(TCancelOperationReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
CancelOperation(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
cancelOperation(OperationHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
cancelRowUpdates() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
cancelToken(Token<DelegationTokenIdentifier>, String) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
canConvertBucketMapJoinToSMBJoin(MapJoinOperator, Stack<Node>, SortBucketJoinProcCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
canConvertJoinToBucketMapJoin(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
canConvertJoinToSMBJoin(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
canConvertJoinToSMBJoin(JoinOperator, SortBucketJoinProcCtx, ParseContext, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinOptimizer
 
canConvertMapJoinToBucketMapJoin(MapJoinOperator, BucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
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
 
canDropPartition(Table, Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
canIterateOutput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
canIterateOutput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
canJdoUseStringsWithIntegral() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
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
 
cappedCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
cappedCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
cappedCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
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
 
caseExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
caseExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
CastBooleanToCharViaLongToChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastBooleanToCharViaLongToChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToCharViaLongToChar
 
CastBooleanToCharViaLongToChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToCharViaLongToChar
 
CastBooleanToStringViaLongToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastBooleanToStringViaLongToString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
CastBooleanToStringViaLongToString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
CastBooleanToVarCharViaLongToVarChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastBooleanToVarCharViaLongToVarChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
CastBooleanToVarCharViaLongToVarChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
CastDateToBooleanViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastDateToBooleanViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDateToBooleanViaLongToLong
 
CastDateToBooleanViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDateToBooleanViaLongToLong
 
CastDateToChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastDateToChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
CastDateToChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
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
 
CastDateToVarChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastDateToVarChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
CastDateToVarChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
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
 
CastDecimalToChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
To support vectorized cast of decimal to string.
CastDecimalToChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
CastDecimalToChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
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
 
CastDecimalToVarChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
To support vectorized cast of decimal to string.
CastDecimalToVarChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
CastDecimalToVarChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
CastDoubleToBooleanViaDoubleToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastDoubleToBooleanViaDoubleToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
CastDoubleToBooleanViaDoubleToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
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
 
CastDoubleToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastDoubleToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
CastDoubleToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
CastDoubleToTimestampViaDoubleToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastDoubleToTimestampViaDoubleToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
CastDoubleToTimestampViaDoubleToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
castExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
castExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
CastLongToBooleanViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastLongToBooleanViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
CastLongToBooleanViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
CastLongToChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastLongToChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
CastLongToChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
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
 
CastLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
CastLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
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
 
CastLongToTimestampViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastLongToTimestampViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
CastLongToTimestampViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
CastLongToVarChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastLongToVarChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToVarChar
 
CastLongToVarChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToVarChar
 
CastMillisecondsLongToTimestampViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastMillisecondsLongToTimestampViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
CastMillisecondsLongToTimestampViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
CastStringGroupToChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastStringGroupToChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
 
CastStringGroupToChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
 
CastStringGroupToVarChar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastStringGroupToVarChar(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
 
CastStringGroupToVarChar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
 
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
 
CastStringToIntervalDayTime - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Casts a string vector to a interval day-time vector.
CastStringToIntervalDayTime() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalDayTime
 
CastStringToIntervalDayTime(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalDayTime
 
CastStringToIntervalYearMonth - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Casts a string vector to a interval year-month vector.
CastStringToIntervalYearMonth() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
CastStringToIntervalYearMonth(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
CastTimestampToBooleanViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastTimestampToBooleanViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
CastTimestampToBooleanViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
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
 
CastTimestampToDoubleViaLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastTimestampToDoubleViaLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
CastTimestampToDoubleViaLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
CastTimestampToLongViaLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
CastTimestampToLongViaLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
CastTimestampToLongViaLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
CatchallExceptionMapper - Class in org.apache.hive.hcatalog.templeton
Map all exceptions to the Jersey response.
CatchallExceptionMapper() - Constructor for class org.apache.hive.hcatalog.templeton.CatchallExceptionMapper
 
cboInfo - Variable in class org.apache.hadoop.hive.ql.Context
 
cboSucceeded - Variable in class org.apache.hadoop.hive.ql.Context
 
ceiling(int, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
ceiling(int, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
changeScaleDestructive(short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Changes the scaling of this Decimal128, preserving the represented value.
channelInactive(ChannelHandlerContext) - Method in class org.apache.hive.spark.client.rpc.RpcDispatcher
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.hive.spark.client.rpc.RpcDispatcher
 
CHAR - Static variable in class org.apache.hive.hcatalog.data.DataType
 
CHAR_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
CHAR_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
CHAR_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
CHAR = 17;
CHARACTER_MAXIMUM_LENGTH - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
characterCount(byte[]) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
characterCount(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
CharScalarConcatStringGroupCol - 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.
CharScalarConcatStringGroupCol(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CharScalarConcatStringGroupCol
 
CharScalarConcatStringGroupCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CharScalarConcatStringGroupCol
 
CharScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
CharScalarEqualStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarEqualStringGroupColumn
 
CharScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarEqualStringGroupColumn
 
CharScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
CharScalarGreaterEqualStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterEqualStringGroupColumn
 
CharScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterEqualStringGroupColumn
 
CharScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
CharScalarGreaterStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterStringGroupColumn
 
CharScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterStringGroupColumn
 
CharScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
CharScalarLessEqualStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessEqualStringGroupColumn
 
CharScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessEqualStringGroupColumn
 
CharScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
CharScalarLessStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessStringGroupColumn
 
CharScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessStringGroupColumn
 
CharScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
CharScalarNotEqualStringGroupColumn(HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarNotEqualStringGroupColumn
 
CharScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarNotEqualStringGroupColumn
 
charset - Variable in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
charSetString(String, String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
charSetStringLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
charSetStringLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
charTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
CharTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
 
CharTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
 
CharTypeInfo(int) - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
 
charTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
charTypePattern - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
charVarcharTypePattern - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
check(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.BeginChecker
 
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.
check(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.ComplexChecker
 
check(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.EndChecker
 
check(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.MiddleChecker
 
check(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.NoneChecker
 
check_lock(CheckLockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
check_lock(CheckLockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
check_lock(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
check_lock(CheckLockRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
check_lock(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
checkAndConvertBucketMapJoin(ParseContext, MapJoinOperator, String, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.BucketMapjoinProc
Check if a mapjoin can be converted to a bucket mapjoin, and do the version if possible.
checkAndDelete(String, CuratorFramework) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
Check to see if a job is more than maxage old, and delete it if so.
checkAndGenObject() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
checkArgGroups(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], PrimitiveObjectInspectorUtils.PrimitiveGrouping...) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
checkArgPrimitive(ObjectInspector[], int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
checkArgs(PrimitiveObjectInspector.PrimitiveCategory, PrimitiveObjectInspector.PrimitiveCategory) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseDTI
 
checkArgsSize(ObjectInspector[], int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
checkBucketedTable(Table, ParseContext, PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.TableScanRule
 
checkConvertBucketMapJoin(BucketJoinProcCtx, Map<String, Operator<? extends OperatorDesc>>, Map<Byte, List<ExprNodeDesc>>, String, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
checkConvertJoinToSMBJoin(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
checkDeletePermission(Path, Configuration, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
Checks if delete can be performed on given path by given user.
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.merge.MergeFileTask
 
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
 
checkFileAccess(FileSystem, FileStatus, FsAction) - Static method in class org.apache.hadoop.fs.DefaultFileAccess
 
checkFileAccess(FileSystem, FileStatus, FsAction, String, List<String>) - Static method in class org.apache.hadoop.fs.DefaultFileAccess
 
checkFileAccess(FileSystem, FileStatus, FsAction) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
checkFileAccess(FileSystem, FileStatus, FsAction) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Check if the configured UGI has access to the path for the given file system action.
checkFileAccess(FileSystem, FileStatus, FsAction) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
checkFileAccessWithImpersonation(FileSystem, FileStatus, FsAction, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
Perform a check to determine if the user is able to access the file passed in.
checkGroupByOperatorProcessed(GroupByOptimizer.GroupByOptimizerContext, GroupByOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
checkIfPrimitive(ObjectInspector[], int, String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSoundex
 
checkIfStringGroup(ObjectInspector[], int, String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSoundex
 
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.
checkInterrupted() - Static method in class org.apache.hadoop.hive.common.HiveInterruptUtils
Checks if the current thread has been interrupted and throws RuntimeException is it has.
CheckJDOException - Class in org.apache.hadoop.hive.ql.metadata
Check if this is a javax.jdo.JDODataStoreException
CheckJDOException() - Constructor for class org.apache.hadoop.hive.ql.metadata.CheckJDOException
 
checkJobContextIfRunningFromBackend(JobContext) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
checkJobTracker(JobConf, Log) - Static method in class org.apache.hadoop.hive.ql.exec.mr.Throttle
Fetch http://tracker.om:/gc.jsp?threshold=period.
checkLock(long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
checkLock(long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Check the status of a set of locks requested via a IMetaStoreClient.lock(org.apache.hadoop.hive.metastore.api.LockRequest) call.
checkLock(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
CheckLockRequest - Class in org.apache.hadoop.hive.metastore.api
 
CheckLockRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
CheckLockRequest(long) - Constructor for class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
CheckLockRequest(CheckLockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.CheckLockRequest
Performs a deep copy on other.
CheckLockRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
checkMapJoin(int, JoinCondDesc[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
checkMemory(double) - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
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.
checkMultiReduceOperator() - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
We check if a vertex has multiple reduce operators.
checkNumReducer(int, int) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
If number of reducers for RS is -1, the RS can have any number of reducers.
checkObjectByteInfo(ObjectInspector, byte[], int, LazyBinaryUtils.RecordInfo, LazyBinaryUtils.VInt) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Check a particular field and set its size and offset in bytes based on the field type and the bytes arrays.
checkOrder(String, String) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat
Update the out table, and output an empty key as the key.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
 
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
 
checkOutputSpecs(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
 
checkPartitionsCoveredByIndex(TableScanOperator, ParseContext, 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.
checkPartitionsMatch(Path) - Method in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
Validates that each input path belongs to the same partition since each mapper merges the input to a single output directory
checkPath(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
checkPermissions(Configuration, Path, EnumSet<FsAction>) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
Checks the permissions for the given path and current user on Hadoop FS.
checkPermissions(FileSystem, FileStatus, EnumSet<FsAction>, String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
Checks the permissions for the given path and current user on Hadoop FS.
checkPrecisionOverflow(int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Throws an exception if the value of this object exceeds the maximum value for the given precision.
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>, HiveAuthzContext) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizationValidator
see HiveAuthorizer.checkPrivileges
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>, HiveAuthzContext) - 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>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveV1Authorizer
 
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.DummyHiveAuthorizationValidator
 
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>, HiveAuthzContext) - 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
 
checkRetryable(Connection, SQLException, String) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Determine if an exception was such that it makse sense to retry.
checkSortGroupBy(Stack<Node>, GroupByOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
checkStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
checkTimeout() - Static method in class org.apache.hadoop.hive.metastore.Deadline
Check whether the long running method timeout.
checkType(ColumnStatisticsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
checkType(FireEventRequestData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
checkType(RequestPartsSpec._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
checkType(PropValueUnion._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
checkType(TColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
checkType(TColumnValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
checkType(TGetInfoValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
checkType(TTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
checkType(TTypeQualifierValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.AddPartitionMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.AlterPartitionMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.AlterTableMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.CreateTableMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.DropPartitionMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.DropTableMessage
 
checkValid() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
Class invariant.
checkValid() - Method in class org.apache.hive.hcatalog.messaging.InsertMessage
 
checkValidity() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
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).
childExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Child expressions are evaluated post order.
childOperators - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
childOperatorsArray - Variable in class org.apache.hadoop.hive.ql.exec.Operator
Cache childOperators in an array for faster access.
childOperatorsTag - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
childOut - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Standard output from any child process(es).
children - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
children - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
childSpecPathDynLinkedPartitions - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
childTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
childToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
childToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
CLASS_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
CLASS_NAME - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
CLASS_NAME - Static variable in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
ClassicTableTypeMapping - Class in org.apache.hive.service.cli.operation
ClassicTableTypeMapping.
ClassicTableTypeMapping() - Constructor for class org.apache.hive.service.cli.operation.ClassicTableTypeMapping
 
ClassicTableTypeMapping.ClassicTableTypes - Enum in org.apache.hive.service.cli.operation
 
classifyOperators(Operator<?>, Set<Class<? extends Operator<?>>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
Given an operator and a set of classes, it classifies the operators it finds in the stream depending on the classes they instantiate.
classifyOperatorsUpstream(Operator<?>, Set<Class<? extends Operator<?>>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
Given an operator and a set of classes, it classifies the operators it finds upstream depending on the classes it instantiates.
className - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.StoredByDesc
 
ClassNameCompleter - Class in org.apache.hive.beeline
the completer is original provided in JLine 0.9.94 and is being removed in 2.12.
ClassNameCompleter(String...) - Constructor for class org.apache.hive.beeline.ClassNameCompleter
 
CLAZZ_FILE_EXT - Static variable in class org.apache.hive.common.util.HiveTestUtils
 
clazzFileNameExtension - Static variable in class org.apache.hive.beeline.ClassNameCompleter
 
clean(HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
clean(AsyncMethodCallback<ThriftHive.AsyncClient.clean_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
clean(AsyncMethodCallback<ThriftHive.AsyncClient.clean_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
clean() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
clean() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
cleanDb() - Static method in class org.apache.hadoop.hive.metastore.txn.TxnDbUtil
 
cleanEmptyAbortedTxns() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
Clean up aborted transactions from txns that have no components in txn_components.
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
 
CLEANING_RESPONSE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
cleanNotificationEvents(int) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
cleanNotificationEvents(int) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Remove older notification events.
cleanseCommand(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
cleanseCommand(String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Clear any client specific tags
cleanUp(String) - Method in class org.apache.hadoop.hive.hbase.HBaseStatsAggregator
 
cleanup(int) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
cleanup() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
cleanup() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
cleanup() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
cleanup(DoubleColumnVector, int[], boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
cleanup(DoubleColumnVector, int[], boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
cleanup(DoubleColumnVector, int[], boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
cleanup(DoubleColumnVector, int[], boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorSpark
 
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.
cleanup() - Method in class org.apache.hive.beeline.util.QFileClient
 
cleanupEvents() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
cleanupEvents() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
cleanupJob(JobContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
cleanupLocationsAfterEvent() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
cleanupLocationsAfterEvent() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
cleanupLocationsPerRetry() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
cleanupLocationsPerRetry() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
cleanupOnFailure(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatStorer
 
cleanupOperationLog() - Method in class org.apache.hive.service.cli.operation.Operation
 
cleanUpScratchDir(HiveConf) - Static method in class org.apache.hadoop.hive.common.ServerUtils
 
cleanupScratchDir() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
clear() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
clear() - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
Removes all the keys and values from this MetricsMBean.
clear() - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
clear() - Method in class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
clear() - Static method in class org.apache.hadoop.hive.metastore.Deadline
remove the registered Deadline threadlocal object from current thread.
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.BytesBytesMultiHashMap
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
clear() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
Clears the contents of the table.
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
 
clear() - Static method in class org.apache.hadoop.hive.ql.io.IOContext
 
clear() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
clear() - Method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils.ByteBufferAllocatorPool
 
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.parse.UnparseTranslator
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
clear() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
clear() - Method in class org.apache.hadoop.hive.ql.session.LineageState
Clear all lineage states
clear() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
clear() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
clear() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Removes all elements.
clear(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Clear the map.
clear(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
clear() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
clear() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.Position
 
clear() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
clear() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
clear() - Method in class org.apache.hive.common.util.BloomFilter.BitSet
Clear the bit set.
clear() - Method in interface org.apache.hive.hcatalog.streaming.RecordWriter
Clear bufferred writes.
clear() - Method in class org.apache.hive.service.cli.TableSchema
 
clear() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
clear() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
clear() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
clear() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
clear() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
clear() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
clear() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
clear() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
clear() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
clear() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
clear() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
clear() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
clear() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
clear() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
clear() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
clear() - Method in class org.apache.hive.service.cli.thrift.TRow
 
clear() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
clear() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
clear() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
clear() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
clear() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
clear() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
clear() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
clear() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
clear() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
clear() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
clear() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
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.
clearBatch() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
clearBatch() - Method in class org.apache.hive.jdbc.HiveStatement
 
clearBinaryStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
clearBitset() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
clearBloomFilter() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
clearBucketStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
clearColStats() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
clearColumn() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint32 column = 2;
clearColumnBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
clearColumns() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
clearCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional .orc.proto.CompressionKind compression = 2;
clearCompressionBlockSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 compressionBlockSize = 3;
clearContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 contentLength = 2;
clearCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
clearDataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 dataLength = 3;
clearDateStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
clearDecimalStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
clearDictionarySize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional uint32 dictionarySize = 2;
clearDistinctFuncExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
clearDoubleStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
clearEntry() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
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.
clearFieldNames() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
clearFilters() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
clearFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 footerLength = 1;
clearFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 footerLength = 4;
clearHasNull() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional bool hasNull = 10;
clearHeaderLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 headerLength = 1;
clearIndexLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 indexLength = 2;
clearIntStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
clearIpAddress() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
clearKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
clearKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional .orc.proto.Stream.Kind kind = 1;
clearKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional .orc.proto.Type.Kind kind = 1;
clearLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint64 length = 3;
clearMagic() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 maximum = 2;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double maximum = 2;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 maximum = 2;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
clearMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 maximum = 2;
clearMaximumLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 maximumLength = 4;
clearMetaCallTiming() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
clearMetadata() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
clearMetadataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 metadataLength = 5;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 minimum = 1;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double minimum = 1;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 minimum = 1;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
clearMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 minimum = 1;
clearName() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
clearNodeScope(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
clearNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 numberOfRows = 6;
clearNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 numberOfRows = 5;
clearNumberOfValues() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional uint64 numberOfValues = 1;
clearNumHashFunctions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
optional uint32 numHashFunctions = 1;
clearOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 offset = 1;
clearParameters() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
clearParameters() - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
clearPositions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
clearPrecision() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 precision = 5;
clearProxyUserName() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
clearQueries() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
clearRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint32 rowIndexStride = 8;
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.FlatRowContainer
 
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.
clearRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
clearScale() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 scale = 6;
clearSerDeInfo() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
clearStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
clearStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
clearStreams() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
clearStringStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
clearStripes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
clearStripeStats() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
clearSubtypes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
clearSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
optional sint64 sum = 1;
clearSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
clearSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double sum = 3;
clearSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 sum = 3;
clearSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional sint64 sum = 3;
clearTimestampStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
clearTypes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
clearUserName() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
clearValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional bytes value = 2;
clearVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
clearWarnings() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
clearWarnings() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
clearWarnings() - Method in class org.apache.hive.jdbc.HiveConnection
 
clearWarnings() - Method in class org.apache.hive.jdbc.HiveStatement
 
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
 
clearWorkMapForConf(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
clearWriterTimezone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
clearWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint32 writerVersion = 6;
CliDriver - Class in org.apache.hadoop.hive.cli
CliDriver.
CliDriver() - Constructor for class org.apache.hadoop.hive.cli.CliDriver
 
clientKill() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
clientRenew() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This method clears the private member variables.
clientStart() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
HWISessionItem is a Runnable instance.
ClientStatsPublisher - Interface in org.apache.hadoop.hive.ql.stats
 
cliname - Variable in class org.apache.hadoop.hive.common.cli.CommonCliOptions
The name of this cli.
CLIService - Class in org.apache.hive.service.cli
CLIService.
CLIService(HiveServer2) - Constructor for class org.apache.hive.service.cli.CLIService
 
cliService - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
CLIServiceClient - Class in org.apache.hive.service.cli
CLIServiceClient.
CLIServiceClient() - Constructor for class org.apache.hive.service.cli.CLIServiceClient
 
CLIServiceUtils - Class in org.apache.hive.service.cli
CLIServiceUtils.
CLIServiceUtils() - Constructor for class org.apache.hive.service.cli.CLIServiceUtils
 
CliSessionState - Class in org.apache.hadoop.hive.cli
SessionState for hive cli.
CliSessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
clone() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
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.exec.vector.VectorHashKeyWrapper
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
clone() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.AbstractVectorDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics.Range
 
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(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
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.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() - Method in interface org.apache.hadoop.hive.ql.plan.VectorDesc
 
clone() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
CLONE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
cloneBaseWork(BaseWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Clones using the powers of XML.
cloneConf() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
clonedConf - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
clonedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
clonedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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, List<Operator<?>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
cloneOriginalParentsList(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
clonePlan(MapredWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Clones using the powers of XML.
cloneQBJoinTreeProps(JoinDesc) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
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.accumulo.mr.HiveAccumuloRecordReader
 
close() - Method in class org.apache.hadoop.hive.cli.CliSessionState
 
close() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Closes scope, and records the time taken
close() - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
close() - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
close(boolean) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat.Base64RecordWriter
 
close() - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFCount2
 
close() - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFExplode2
 
close() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordReader
 
close() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordWriter
 
close() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
close() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
close connection to meta store
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.persistence.RowContainer
 
close() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
close() - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
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() - Method in class org.apache.hadoop.hive.ql.exec.SecureCmdDoAs
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
close() - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
Close session and release resources.
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMapRecordHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
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, boolean) - 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
Deprecated.
 
close() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughRecordWriter
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat.IgnoreKeyWriter
Deprecated.
 
close() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileMapper
 
close() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.orc.MetadataReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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.orc.WriterImpl
 
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.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.OperationLog
Close this OperationLog when operation is closed.
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
 
close() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Close the connection to the Job Tracker.
close() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
close() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
close() - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
close() - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
close() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
close() - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
close() - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Close the connection to the Job Tracker.
close() - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Close the connection to the Job Tracker.
close() - Method in class org.apache.hive.beeline.BeeLine
 
close(String) - Method in class org.apache.hive.beeline.Commands
Close the current connection.
close() - Method in class org.apache.hive.beeline.OutputFile
 
close() - Method in class org.apache.hive.hcatalog.api.HCatClient
Close the hcatalog client.
close() - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
close() - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
close() - Method in interface org.apache.hive.hcatalog.streaming.StreamingConnection
Close connection
close() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Close the TransactionBatch
close() - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
Cleanup
close() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
For storage methods that require a connection, this is a hint that it's time to close the connection.
close() - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
close() - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Close this ZK connection.
close() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
close() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
close() - Method in class org.apache.hive.jdbc.HiveConnection
 
close() - Method in class org.apache.hive.jdbc.HiveMetaDataResultSet
 
close() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
close() - Method in class org.apache.hive.jdbc.HiveStatement
 
close() - Method in class org.apache.hive.service.cli.operation.HiveCommandOperation
 
close() - Method in class org.apache.hive.service.cli.operation.MetadataOperation
 
close() - Method in class org.apache.hive.service.cli.operation.Operation
 
close() - Method in class org.apache.hive.service.cli.operation.SQLOperation
 
close() - Method in interface org.apache.hive.service.cli.session.HiveSession
close the session
close() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
close() - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
Close the file systems for the session and remove it from the FileSystem cache.
close() - Method in class org.apache.hive.spark.client.rpc.Rpc
 
close() - Method in class org.apache.hive.spark.client.rpc.RpcServer
 
closeall(String) - Method in class org.apache.hive.beeline.Commands
Close all connections.
closeAndOpen(TezSessionState, HiveConf, boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
closeAndOpen(TezSessionState, HiveConf, String[], boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
closeAndReleaseInstance() - Static method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.CuratorFrameworkSingleton
 
closeBatch() - Method in interface org.apache.hive.hcatalog.streaming.RecordWriter
Close the RecordUpdater.
closeClassLoader(ClassLoader) - Static method in class org.apache.hadoop.hive.common.JavaUtils
 
closeClassLoadersTo(ClassLoader, ClassLoader) - Static method in class org.apache.hadoop.hive.common.JavaUtils
 
closeConnection() - Method in class org.apache.hadoop.hive.hbase.HBaseStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.hbase.HBaseStatsPublisher
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorSpark
 
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.
closeCUDFLoaders() - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
closeCurrent() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
closeDbConn(Connection) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
ClosedOrCancelledStatementException - Exception in org.apache.hive.jdbc
 
ClosedOrCancelledStatementException(String) - Constructor for exception org.apache.hive.jdbc.ClosedOrCancelledStatementException
 
closeExpiredOperations() - Method in interface org.apache.hive.service.cli.session.HiveSession
 
closeExpiredOperations() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
closeFs(FileSystem) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
closeHiveClientQuietly(IMetaStoreClient) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
closeNodeScope(Node, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
closeNodeScope(Node, boolean) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
closeOnCompletion() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
closeOnCompletion() - Method in class org.apache.hive.jdbc.HiveStatement
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
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.CommonMergeJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
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
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Operator specific close routine.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.OrcFileMergeOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
On close, make sure a partially filled overflow batch gets forwarded.
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.VectorMapJoinBaseOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
closeOperation(OperationHandle) - Method in class org.apache.hive.service.cli.CLIService
 
closeOperation(OperationHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
closeOperation(OperationHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
closeOperation(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
closeOperation(OperationHandle) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
closeOperation(OperationHandle) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
CloseOperation(TCloseOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseOperation_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
CloseOperation(TCloseOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseOperation_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
CloseOperation(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
CloseOperation(TCloseOperationReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
CloseOperation(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
closeOperation(OperationHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
closeRecordProcessor() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
Close the record processor.
closeRecordProcessor() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunctionResultList
 
closeRecordProcessor() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunctionResultList
 
closeSession(SparkSession) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager
Close the given session and return it to pool.
closeSession(SparkSession) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
 
closeSession(SessionHandle) - Method in class org.apache.hive.service.cli.CLIService
 
closeSession(SessionHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
closeSession(SessionHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
closeSession(SessionHandle) - Method in class org.apache.hive.service.cli.session.SessionManager
 
CloseSession(TCloseSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseSession_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
CloseSession(TCloseSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseSession_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
CloseSession(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
CloseSession(TCloseSessionReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
CloseSession(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
closeSession(SessionHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
closeStmt(Statement) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Close statement instance.
closeStorage() - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
closeStorage() - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
For storage methods that require a connection, this is a hint that it's time to close the connection.
closeStorage() - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
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
 
clusterByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
clusterByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
clusteredBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
clusterHadoop() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
clusterHcat() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
clusterPython() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
cmd - Variable in class org.apache.hadoop.hive.ql.Context
 
cmdProperties - Variable in class org.apache.hadoop.hive.cli.CliSessionState
properties set from -hiveconf via cmdline.
cntr - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
cntr - Variable in class org.apache.hadoop.hive.ql.exec.MapOperator
 
cntr - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
codec - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
codec - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
CodecPool - Class in org.apache.hadoop.hive.ql.io
A global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs.
col - Variable in class org.apache.hadoop.hive.serde2.ColumnSet
 
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
 
colExprMap - Variable in class org.apache.hadoop.hive.ql.exec.Operator
A map of output column name to input expression map.
collations(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdCollation
 
collations(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdCollation
 
collect(String[]) - Method in interface org.apache.hadoop.hive.contrib.mr.Output
Add a row to the output.
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(BytesWritable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
collect(HiveKey, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
 
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
 
COLLECTION_DELIM - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
COLLECTION_TYPES - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
collectionItemsTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
collectionItemsTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
collectionItemsTerminatedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
CollectionTypes - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
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 - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
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
collectStatistics(HiveConf, PrunedPartitionList, Table, List<ColumnInfo>, List<String>, List<String>, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
colNum - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
COLON - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
COLON - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
COLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
COLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
COLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
COLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
COLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
COLON - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
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
 
cols(List<HCatFieldSchema>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for Column schemas.
ColStatistics - Class in org.apache.hadoop.hive.ql.plan
 
ColStatistics(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ColStatistics
 
ColStatistics() - Constructor for class org.apache.hadoop.hive.ql.plan.ColStatistics
 
ColStatistics.Range - Class in org.apache.hadoop.hive.ql.plan
 
ColStatistics.Range(Number, Number) - Constructor for class org.apache.hadoop.hive.ql.plan.ColStatistics.Range
 
colStatNames - Static variable in interface org.apache.hadoop.hive.metastore.IExtrapolatePartStatus
The sequence of colStatNames.
COLSTATS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
colStatTypes - Static variable in interface org.apache.hadoop.hive.metastore.IExtrapolatePartStatus
 
colType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
colTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
COLUMN - Static variable in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
column - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
Column - Class in org.apache.hive.service.cli
Column.
Column(Type, BitSet, Object) - Constructor for class org.apache.hive.service.cli.Column
 
Column(Type) - Constructor for class org.apache.hive.service.cli.Column
 
Column(TColumn) - Constructor for class org.apache.hive.service.cli.Column
 
COLUMN_COMMENTS_DELIMITER - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
COLUMN_MAPPINGS - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
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
 
COLUMN_STATS_ACCURATE - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
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 - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
ColumnAccessInfo - Class in org.apache.hadoop.hive.ql.parse
 
ColumnAccessInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
 
ColumnarSerDe - Class in org.apache.hadoop.hive.serde2.columnar
ColumnarSerDe is used for columnar based storage supported by RCFile.
ColumnarSerDe() - Constructor for class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
ColumnarSerDeBase - Class in org.apache.hadoop.hive.serde2.columnar
 
ColumnarSerDeBase() - Constructor for class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
ColumnarStruct - Class in org.apache.hadoop.hive.serde2.columnar
ColumnarStruct is different from LazyStruct in that ColumnarStruct's field Object get parsed at its initialize time when call ColumnarStructBase.init(BytesRefArrayWritable cols), while LazyStruct parse fields in a lazy way.
ColumnarStruct(ObjectInspector, List<Integer>, Text) - Constructor for class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
Construct a ColumnarStruct object with the TypeInfo.
ColumnarStructBase - Class in org.apache.hadoop.hive.serde2.columnar
 
ColumnarStructBase(ObjectInspector, List<Integer>) - Constructor for class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
 
columnAssignmentClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnAttributes - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
ColumnBasedSet - Class in org.apache.hive.service.cli
ColumnBasedSet.
ColumnBasedSet(TableSchema) - Constructor for class org.apache.hive.service.cli.ColumnBasedSet
 
ColumnBasedSet(TRowSet) - Constructor for class org.apache.hive.service.cli.ColumnBasedSet
 
ColumnDesc - Class in org.apache.hive.hcatalog.templeton
A description of the column to create.
ColumnDesc() - Constructor for class org.apache.hive.hcatalog.templeton.ColumnDesc
 
ColumnDesc(String, String, String) - Constructor for class org.apache.hive.hcatalog.templeton.ColumnDesc
Create a new ColumnDesc
ColumnDescriptor - Class in org.apache.hive.service.cli
ColumnDescriptor.
ColumnDescriptor(String, String, TypeDescriptor, int) - Constructor for class org.apache.hive.service.cli.ColumnDescriptor
 
ColumnDescriptor(TColumnDesc) - Constructor for class org.apache.hive.service.cli.ColumnDescriptor
 
ColumnDescriptor(FieldSchema, int) - Constructor for class org.apache.hive.service.cli.ColumnDescriptor
 
ColumnEncoding - Enum in org.apache.hadoop.hive.accumulo.columns
Encapsulate the encoding of values within the given column in Accumulo
columnFamily - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
columnFamily - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
columnFamilyBytes - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
columnId - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
 
columnIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow.Assigner
 
columnIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow.Extractor
 
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
 
ColumnMapper - Class in org.apache.hadoop.hive.accumulo.columns
 
ColumnMapper(String, String, List<String>, List<TypeInfo>) - Constructor for class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
Create a mapping from Hive columns (rowID and column) to Accumulo columns (column family and qualifier).
columnMapper - Variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
ColumnMapping - Class in org.apache.hadoop.hive.accumulo.columns
 
ColumnMapping(String, ColumnEncoding, String, String) - Constructor for class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
 
ColumnMapping(String, ColumnEncoding, String, TypeInfo) - Constructor for class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
 
columnMapping - Variable in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
ColumnMappingFactory - Class in org.apache.hadoop.hive.accumulo.columns
 
ColumnMappingFactory() - Constructor for class org.apache.hadoop.hive.accumulo.columns.ColumnMappingFactory
 
ColumnMappings - Class in org.apache.hadoop.hive.hbase
 
ColumnMappings(List<ColumnMappings.ColumnMapping>, int) - Constructor for class org.apache.hadoop.hive.hbase.ColumnMappings
 
ColumnMappings(List<ColumnMappings.ColumnMapping>, int, int) - Constructor for class org.apache.hadoop.hive.hbase.ColumnMappings
 
columnMappings - Variable in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
ColumnMappings.ColumnMapping - Class in org.apache.hadoop.hive.hbase
Represents a mapping from a single Hive column to an HBase column qualifier, column family or row key.
columnName - Variable in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
 
columnName - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveColumn
 
columnName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnName - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
columnNameColonType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameColonTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameCommentList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameOrder() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameOrderList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNames - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
columnNames - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
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
 
columnNameType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ColumnProjectionUtils - Class in org.apache.hadoop.hive.serde2
ColumnProjectionUtils.
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.ColumnPrunerLimitProc - Class in org.apache.hadoop.hive.ql.optimizer
 
ColumnPrunerProcFactory.ColumnPrunerLimitProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLimitProc
 
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.ColumnPrunerScriptProc - Class in org.apache.hadoop.hive.ql.optimizer
 
ColumnPrunerProcFactory.ColumnPrunerScriptProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerScriptProc
 
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
 
columnQualifier - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
columnQualifierBytes - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
columnQualifierPrefix - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
columnRefOrder() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnRefOrderInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnRefOrderInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
columnRefOrderNotInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnRefOrderNotInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
COLUMNS - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
columns - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For a single row, the split on the primary separator.
columns(String) - Method in class org.apache.hive.beeline.Commands
 
columns - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
COLUMNS_BUFFER_SIZE_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile.Writer
 
COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
COLUMNS_TYPES - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
ColumnSet - Class in org.apache.hadoop.hive.serde2
ColumnSet.
ColumnSet() - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
ColumnSet(ArrayList<String>) - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
ColumnStatistics - Class in org.apache.hadoop.hive.metastore.api
 
ColumnStatistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
ColumnStatistics(ColumnStatisticsDesc, List<ColumnStatisticsObj>) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
ColumnStatistics(ColumnStatistics) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatistics
Performs a deep copy on other.
ColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics that are available for all types of columns.
ColumnStatistics._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnStatisticsData - Class in org.apache.hadoop.hive.metastore.api
 
ColumnStatisticsData() - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
ColumnStatisticsData(ColumnStatisticsData._Fields, Object) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
ColumnStatisticsData(ColumnStatisticsData) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
ColumnStatisticsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnStatisticsDesc - Class in org.apache.hadoop.hive.metastore.api
 
ColumnStatisticsDesc() - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
ColumnStatisticsDesc(boolean, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
ColumnStatisticsDesc(ColumnStatisticsDesc) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Performs a deep copy on other.
ColumnStatisticsDesc._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnStatisticsObj - Class in org.apache.hadoop.hive.metastore.api
 
ColumnStatisticsObj() - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
ColumnStatisticsObj(String, String, ColumnStatisticsData) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
ColumnStatisticsObj(ColumnStatisticsObj) - Constructor for class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
Performs a deep copy on other.
ColumnStatisticsObj._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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, 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
 
ColumnStatsTask - Class in org.apache.hadoop.hive.ql.exec
ColumnStatsTask implementation.
ColumnStatsTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
ColumnStatsUpdateTask - Class in org.apache.hadoop.hive.ql.exec
ColumnStatsUpdateTask implementation.
ColumnStatsUpdateTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnStatsUpdateTask
 
ColumnStatsUpdateWork - Class in org.apache.hadoop.hive.ql.plan
ColumnStatsUpdateWork implementation.
ColumnStatsUpdateWork(ColumnStatsDesc, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ColumnStatsUpdateWork
 
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.accumulo.columns.ColumnMapping
 
columnType - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveColumn
 
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.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
columnTypes - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
ColumnValue - Class in org.apache.hive.service.cli
Protocols before HIVE_CLI_SERVICE_PROTOCOL_V6 (used by RowBasedSet)
ColumnValue() - Constructor for class org.apache.hive.service.cli.ColumnValue
 
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.
ColumnVector.Type - Enum in org.apache.hadoop.hive.ql.exec.vector
 
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.AvoidSplitCombination - Interface in org.apache.hadoop.hive.ql.io
This is a marker interface that is used to identify the formats where combine split generation is not applicable
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(CombineFileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(JobConf, CombineFileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(JobConf, CombineFileSplit, Map<String, PartitionDesc>) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveKey - Class in org.apache.hadoop.hive.shims
 
CombineHiveKey(Object) - Constructor for class org.apache.hadoop.hive.shims.CombineHiveKey
 
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
 
combineInts(int, int) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
 
COMMA - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
COMMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
COMMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
COMMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
COMMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
COMMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
COMMA - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
COMMA - Static variable in class org.apache.hive.common.util.HiveStringUtils
 
COMMA_STR - Static variable in class org.apache.hive.common.util.HiveStringUtils
 
Command - Interface in org.apache.hive.hcatalog.api.repl
Interface that abstracts the notion of one atomic command to execute.
COMMAND_PREFIX - Static variable in class org.apache.hive.beeline.BeeLine
 
commandLine - Variable in class org.apache.hadoop.hive.common.cli.CommonCliOptions
 
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 interface.
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, Throwable) - 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
 
CommandProcessorResponse(int, String, String, Schema, Throwable) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
Commands - Class in org.apache.hive.beeline
 
CommaOrSemicolon() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
comment(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc.Builder
Comment.
comment() - Method in class org.apache.hive.hcatalog.api.HCatTable
 
comment(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for table-level comment.
comment - Variable in class org.apache.hive.hcatalog.templeton.ColumnDesc
 
comment - Variable in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
comment - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
commentProvided(char[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
comments(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
commit(String) - Method in class org.apache.hive.beeline.Commands
 
commit(WriterContext) - Method in class org.apache.hive.hcatalog.data.transfer.HCatWriter
This method should be called at master node.
commit(WriterContext) - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
commit() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Commit the currently open transaction
commit() - Method in class org.apache.hive.jdbc.HiveConnection
 
commit_txn(CommitTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.commit_txn_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
commit_txn(CommitTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.commit_txn_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
commit_txn(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
commit_txn(CommitTxnRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
commit_txn(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
commitCreateTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
commitCreateTable(Table) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
commitCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after successfully adding a new table definition to the metastore during CREATE TABLE.
commitDropTable(Table, boolean) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
commitDropTable(Table, boolean) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
commitDropTable(Table, boolean) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after successfully removing a table definition from the metastore during DROP TABLE.
commitJob(OutputFormat, Job) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
commitJob(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry
Trigger commit for TaskAttempt, as specified by the TaskAttemptContext argument.
commitTask(TaskAttemptContext) - Method in interface org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry.TaskCommitterProxy
Call-back for Committer's abortTask().
commitTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
if this is the commit of the first open call then an actual commit is called.
commitTransaction() - Method in interface org.apache.hadoop.hive.metastore.RawStore
if this is the commit of the first open call then an actual commit is called.
commitTxn(long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
commitTxn(long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Commit a transaction.
commitTxn(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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.
CommitTxnRequest - Class in org.apache.hadoop.hive.metastore.api
 
CommitTxnRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
CommitTxnRequest(long) - Constructor for class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
CommitTxnRequest(CommitTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
Performs a deep copy on other.
CommitTxnRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
COMMON_JOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CommonCliOptions - Class in org.apache.hadoop.hive.common.cli
Reusable code for Hive Cli's.
CommonCliOptions(String, boolean) - Constructor for class org.apache.hadoop.hive.common.cli.CommonCliOptions
Create an instance with common options (help, verbose, etc...).
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
 
CommonMergeJoinDesc - Class in org.apache.hadoop.hive.ql.plan
 
CommonMergeJoinDesc(int, int, MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.CommonMergeJoinDesc
 
CommonMergeJoinOperator - Class in org.apache.hadoop.hive.ql.exec
 
CommonMergeJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
commonSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
compact(CompactionRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.compact_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
compact(CompactionRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.compact_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
compact(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
compact(CompactionRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
compact(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
compact(String, String, String, CompactionType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
compact(String, String, String, CompactionType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Send a request to compact a table or partition.
compact(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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
 
CompactionInfo - Class in org.apache.hadoop.hive.metastore.txn
Information on a possible or running compaction.
CompactionInfo(String, String, String, CompactionType) - Constructor for class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
CompactionRequest - Class in org.apache.hadoop.hive.metastore.api
 
CompactionRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
CompactionRequest(String, String, CompactionType) - Constructor for class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
CompactionRequest(CompactionRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.CompactionRequest
Performs a deep copy on other.
CompactionRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionTxnHandler - Class in org.apache.hadoop.hive.metastore.txn
Extends the transaction handler with methods needed only by the compactor threads.
CompactionTxnHandler(HiveConf) - Constructor for class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
 
CompactionType - Enum in org.apache.hadoop.hive.metastore.api
 
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
Deprecated.
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(InputSplit, InputSplit) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex.PathComparatorForSplit
 
compare(HiveDecimalWritable, HiveDecimal) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
compare(HiveDecimal, HiveDecimalWritable) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
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
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable.Comparator
Compare the buffers in serialized form.
compare(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Returns -1 if the first byte sequence is lexicographically less than the second; returns +1 if the second byte sequence is lexicographically less than the first; otherwise return 0.
compare(Object, MapObjectInspector, Object, MapObjectInspector) - Method in class org.apache.hadoop.hive.serde2.objectinspector.CrossMapEqualComparer
 
compare(Object, MapObjectInspector, Object, MapObjectInspector) - Method in class org.apache.hadoop.hive.serde2.objectinspector.FullMapEqualComparer
 
compare(Object, MapObjectInspector, Object, MapObjectInspector) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapEqualComparer
 
compare(Object[], ObjectInspector[], Object[], ObjectInspector[]) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Compare two arrays of objects with their respective arrays of ObjectInspectors.
compare(Object, ObjectInspector, Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Compare two objects with their respective ObjectInspectors.
compare(Object, ObjectInspector, Object, ObjectInspector, MapEqualComparer) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Compare two objects with their respective ObjectInspectors.
compare(Object, MapObjectInspector, Object, MapObjectInspector) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SimpleMapEqualComparer
 
compare(Object, Object) - Static method in class org.apache.hive.hcatalog.data.DataType
 
compare(Object, Object, byte, byte) - Static method in class org.apache.hive.hcatalog.data.DataType
 
COMPARE_OPT_CLASS - Static variable in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
compareFieldColumns(List<FieldSchema>, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
compareOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
CompareOp - Interface in org.apache.hadoop.hive.accumulo.predicate.compare
Handles different types of comparisons in hive predicates.
comparePathKeyStrength(Path, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
comparePathKeyStrength(Path, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
Compares two encrypted path strengths.
comparePathKeyStrength(Path, Path) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
comparePrimitiveObjects(Object, PrimitiveObjectInspector, Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Compare 2 primitive objects.
comparePrimitiveObjectsWithConversion(Object, PrimitiveObjectInspector, Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Compare 2 Primitive Objects with their Object Inspector, conversions allowed.
compareResults() - Method in class org.apache.hive.beeline.util.QFileClient
 
compareSupported(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Whether comparison is supported for this type.
compareTo(Attr) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Attr
 
compareTo(Decimal128) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Compares this Decimal128 with the specified Decimal128.
compareTo(HiveChar) - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
compareTo(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
compareTo(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
compareTo(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
compareTo(HiveVarchar) - Method in class org.apache.hadoop.hive.common.type.HiveVarchar
 
compareTo(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
compareTo(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
compareTo(int[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
compareTo(int, int, int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
compareTo(Object) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
HWIAuth is used in SortedSets(s) the compartTo method is required.
compareTo(HWISessionItem) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
to support sorting/Set.
compareTo(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
compareTo(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
compareTo(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
compareTo(AddPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
compareTo(AggrStats) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
compareTo(AlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
compareTo(BinaryColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
compareTo(BooleanColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
compareTo(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
compareTo(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
compareTo(ColumnStatisticsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
compareTo(ColumnStatisticsDesc) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
compareTo(ColumnStatisticsObj) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
compareTo(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
compareTo(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
compareTo(ConfigValSecurityException) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
compareTo(CurrentNotificationEventId) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
compareTo(Database) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
compareTo(Date) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
compareTo(DateColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
compareTo(Decimal) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
compareTo(DecimalColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
compareTo(DoubleColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
compareTo(DropPartitionsExpr) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
compareTo(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
compareTo(DropPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
compareTo(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
compareTo(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
compareTo(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
compareTo(FireEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
compareTo(FireEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
compareTo(Function) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
compareTo(GetOpenTxnsInfoResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
compareTo(GetOpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
compareTo(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
compareTo(GetPrincipalsInRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
compareTo(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
compareTo(GetRoleGrantsForPrincipalResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
compareTo(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
compareTo(GrantRevokePrivilegeResponse) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
compareTo(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
compareTo(GrantRevokeRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
compareTo(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
compareTo(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
compareTo(HeartbeatTxnRangeResponse) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
compareTo(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
compareTo(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
compareTo(Index) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
compareTo(IndexAlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
compareTo(InsertEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
compareTo(InvalidInputException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
compareTo(InvalidObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
compareTo(InvalidOperationException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
compareTo(InvalidPartitionException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
compareTo(LockComponent) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
compareTo(LockRequest) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
compareTo(LockResponse) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
compareTo(LongColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
compareTo(MetaException) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
compareTo(NoSuchLockException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
compareTo(NoSuchObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
compareTo(NoSuchTxnException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
compareTo(NotificationEvent) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
compareTo(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
compareTo(NotificationEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
compareTo(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
compareTo(OpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
compareTo(Order) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
compareTo(Partition) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
compareTo(PartitionListComposingSpec) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
compareTo(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
compareTo(PartitionsByExprResult) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
compareTo(PartitionSpec) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
compareTo(PartitionSpecWithSharedSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
compareTo(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
compareTo(PartitionsStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
compareTo(PartitionWithoutSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
compareTo(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
compareTo(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
compareTo(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
compareTo(RequestPartsSpec) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
compareTo(ResourceUri) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
compareTo(Role) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
compareTo(RolePrincipalGrant) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
compareTo(Schema) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
compareTo(SerDeInfo) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
compareTo(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
compareTo(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
compareTo(ShowCompactResponse) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
compareTo(ShowCompactResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
compareTo(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
compareTo(ShowLocksResponse) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
compareTo(ShowLocksResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
compareTo(SkewedInfo) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
compareTo(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
compareTo(StringColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
compareTo(Table) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
compareTo(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
compareTo(TableStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
compareTo(ThriftHiveMetastore.abort_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
compareTo(ThriftHiveMetastore.abort_txn_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
compareTo(ThriftHiveMetastore.add_dynamic_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
compareTo(ThriftHiveMetastore.add_dynamic_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
compareTo(ThriftHiveMetastore.add_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
compareTo(ThriftHiveMetastore.add_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
compareTo(ThriftHiveMetastore.add_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
compareTo(ThriftHiveMetastore.add_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
compareTo(ThriftHiveMetastore.add_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
compareTo(ThriftHiveMetastore.add_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
compareTo(ThriftHiveMetastore.add_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
compareTo(ThriftHiveMetastore.add_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
compareTo(ThriftHiveMetastore.add_partitions_pspec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
compareTo(ThriftHiveMetastore.add_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
compareTo(ThriftHiveMetastore.add_partitions_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
compareTo(ThriftHiveMetastore.add_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
compareTo(ThriftHiveMetastore.alter_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
compareTo(ThriftHiveMetastore.alter_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
compareTo(ThriftHiveMetastore.alter_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
compareTo(ThriftHiveMetastore.alter_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
compareTo(ThriftHiveMetastore.alter_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
compareTo(ThriftHiveMetastore.alter_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
compareTo(ThriftHiveMetastore.alter_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
compareTo(ThriftHiveMetastore.alter_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
compareTo(ThriftHiveMetastore.alter_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
compareTo(ThriftHiveMetastore.alter_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
compareTo(ThriftHiveMetastore.alter_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
compareTo(ThriftHiveMetastore.alter_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
compareTo(ThriftHiveMetastore.alter_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
compareTo(ThriftHiveMetastore.alter_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
compareTo(ThriftHiveMetastore.alter_table_with_cascade_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
compareTo(ThriftHiveMetastore.alter_table_with_cascade_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
compareTo(ThriftHiveMetastore.alter_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
compareTo(ThriftHiveMetastore.alter_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
compareTo(ThriftHiveMetastore.append_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
compareTo(ThriftHiveMetastore.append_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
compareTo(ThriftHiveMetastore.append_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
compareTo(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
compareTo(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
compareTo(ThriftHiveMetastore.append_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
compareTo(ThriftHiveMetastore.append_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
compareTo(ThriftHiveMetastore.append_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
compareTo(ThriftHiveMetastore.cancel_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
compareTo(ThriftHiveMetastore.cancel_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
compareTo(ThriftHiveMetastore.check_lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
compareTo(ThriftHiveMetastore.check_lock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
compareTo(ThriftHiveMetastore.commit_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
compareTo(ThriftHiveMetastore.commit_txn_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
compareTo(ThriftHiveMetastore.compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
compareTo(ThriftHiveMetastore.compact_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
compareTo(ThriftHiveMetastore.create_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
compareTo(ThriftHiveMetastore.create_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
compareTo(ThriftHiveMetastore.create_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
compareTo(ThriftHiveMetastore.create_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
compareTo(ThriftHiveMetastore.create_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
compareTo(ThriftHiveMetastore.create_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
compareTo(ThriftHiveMetastore.create_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
compareTo(ThriftHiveMetastore.create_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
compareTo(ThriftHiveMetastore.create_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
compareTo(ThriftHiveMetastore.create_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
compareTo(ThriftHiveMetastore.create_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
compareTo(ThriftHiveMetastore.create_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
compareTo(ThriftHiveMetastore.delete_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
compareTo(ThriftHiveMetastore.delete_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
compareTo(ThriftHiveMetastore.delete_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
compareTo(ThriftHiveMetastore.delete_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
compareTo(ThriftHiveMetastore.drop_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
compareTo(ThriftHiveMetastore.drop_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
compareTo(ThriftHiveMetastore.drop_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
compareTo(ThriftHiveMetastore.drop_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
compareTo(ThriftHiveMetastore.drop_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
compareTo(ThriftHiveMetastore.drop_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
compareTo(ThriftHiveMetastore.drop_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
compareTo(ThriftHiveMetastore.drop_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
compareTo(ThriftHiveMetastore.drop_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
compareTo(ThriftHiveMetastore.drop_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
compareTo(ThriftHiveMetastore.drop_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
compareTo(ThriftHiveMetastore.drop_partitions_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
compareTo(ThriftHiveMetastore.drop_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
compareTo(ThriftHiveMetastore.drop_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
compareTo(ThriftHiveMetastore.drop_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
compareTo(ThriftHiveMetastore.drop_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
compareTo(ThriftHiveMetastore.drop_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
compareTo(ThriftHiveMetastore.drop_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
compareTo(ThriftHiveMetastore.drop_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
compareTo(ThriftHiveMetastore.drop_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
compareTo(ThriftHiveMetastore.exchange_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
compareTo(ThriftHiveMetastore.exchange_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
compareTo(ThriftHiveMetastore.fire_listener_event_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
compareTo(ThriftHiveMetastore.fire_listener_event_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
compareTo(ThriftHiveMetastore.get_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
compareTo(ThriftHiveMetastore.get_aggr_stats_for_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
compareTo(ThriftHiveMetastore.get_all_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
compareTo(ThriftHiveMetastore.get_all_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
compareTo(ThriftHiveMetastore.get_all_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
compareTo(ThriftHiveMetastore.get_all_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
compareTo(ThriftHiveMetastore.get_config_value_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
compareTo(ThriftHiveMetastore.get_config_value_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
compareTo(ThriftHiveMetastore.get_current_notificationEventId_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
compareTo(ThriftHiveMetastore.get_current_notificationEventId_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
compareTo(ThriftHiveMetastore.get_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
compareTo(ThriftHiveMetastore.get_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
compareTo(ThriftHiveMetastore.get_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
compareTo(ThriftHiveMetastore.get_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
compareTo(ThriftHiveMetastore.get_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
compareTo(ThriftHiveMetastore.get_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
compareTo(ThriftHiveMetastore.get_fields_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
compareTo(ThriftHiveMetastore.get_fields_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
compareTo(ThriftHiveMetastore.get_fields_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
compareTo(ThriftHiveMetastore.get_fields_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
compareTo(ThriftHiveMetastore.get_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
compareTo(ThriftHiveMetastore.get_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
compareTo(ThriftHiveMetastore.get_functions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
compareTo(ThriftHiveMetastore.get_functions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
compareTo(ThriftHiveMetastore.get_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
compareTo(ThriftHiveMetastore.get_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
compareTo(ThriftHiveMetastore.get_index_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
compareTo(ThriftHiveMetastore.get_index_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
compareTo(ThriftHiveMetastore.get_indexes_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
compareTo(ThriftHiveMetastore.get_indexes_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
compareTo(ThriftHiveMetastore.get_next_notification_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
compareTo(ThriftHiveMetastore.get_next_notification_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
compareTo(ThriftHiveMetastore.get_open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
compareTo(ThriftHiveMetastore.get_open_txns_info_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
compareTo(ThriftHiveMetastore.get_open_txns_info_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
compareTo(ThriftHiveMetastore.get_open_txns_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
compareTo(ThriftHiveMetastore.get_part_specs_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
compareTo(ThriftHiveMetastore.get_part_specs_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
compareTo(ThriftHiveMetastore.get_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
compareTo(ThriftHiveMetastore.get_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
compareTo(ThriftHiveMetastore.get_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
compareTo(ThriftHiveMetastore.get_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
compareTo(ThriftHiveMetastore.get_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
compareTo(ThriftHiveMetastore.get_partition_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
compareTo(ThriftHiveMetastore.get_partition_names_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
compareTo(ThriftHiveMetastore.get_partition_names_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
compareTo(ThriftHiveMetastore.get_partition_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
compareTo(ThriftHiveMetastore.get_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
compareTo(ThriftHiveMetastore.get_partition_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partition_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
compareTo(ThriftHiveMetastore.get_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_expr_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_expr_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
compareTo(ThriftHiveMetastore.get_partitions_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
compareTo(ThriftHiveMetastore.get_partitions_by_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
compareTo(ThriftHiveMetastore.get_partitions_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
compareTo(ThriftHiveMetastore.get_partitions_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
compareTo(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
compareTo(ThriftHiveMetastore.get_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
compareTo(ThriftHiveMetastore.get_partitions_pspec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
compareTo(ThriftHiveMetastore.get_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
compareTo(ThriftHiveMetastore.get_partitions_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
compareTo(ThriftHiveMetastore.get_partitions_statistics_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
compareTo(ThriftHiveMetastore.get_partitions_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partitions_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
compareTo(ThriftHiveMetastore.get_principals_in_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
compareTo(ThriftHiveMetastore.get_principals_in_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
compareTo(ThriftHiveMetastore.get_privilege_set_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
compareTo(ThriftHiveMetastore.get_privilege_set_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
compareTo(ThriftHiveMetastore.get_role_grants_for_principal_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
compareTo(ThriftHiveMetastore.get_role_grants_for_principal_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
compareTo(ThriftHiveMetastore.get_role_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
compareTo(ThriftHiveMetastore.get_role_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
compareTo(ThriftHiveMetastore.get_schema_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
compareTo(ThriftHiveMetastore.get_schema_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
compareTo(ThriftHiveMetastore.get_schema_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
compareTo(ThriftHiveMetastore.get_schema_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
compareTo(ThriftHiveMetastore.get_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
compareTo(ThriftHiveMetastore.get_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
compareTo(ThriftHiveMetastore.get_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
compareTo(ThriftHiveMetastore.get_table_names_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
compareTo(ThriftHiveMetastore.get_table_names_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
compareTo(ThriftHiveMetastore.get_table_objects_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
compareTo(ThriftHiveMetastore.get_table_objects_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
compareTo(ThriftHiveMetastore.get_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
compareTo(ThriftHiveMetastore.get_table_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
compareTo(ThriftHiveMetastore.get_table_statistics_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
compareTo(ThriftHiveMetastore.get_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
compareTo(ThriftHiveMetastore.get_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
compareTo(ThriftHiveMetastore.get_type_all_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
compareTo(ThriftHiveMetastore.get_type_all_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
compareTo(ThriftHiveMetastore.get_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
compareTo(ThriftHiveMetastore.get_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
compareTo(ThriftHiveMetastore.getMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
compareTo(ThriftHiveMetastore.getMetaConf_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
compareTo(ThriftHiveMetastore.grant_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
compareTo(ThriftHiveMetastore.grant_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
compareTo(ThriftHiveMetastore.grant_revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
compareTo(ThriftHiveMetastore.grant_revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
compareTo(ThriftHiveMetastore.grant_revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
compareTo(ThriftHiveMetastore.grant_revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
compareTo(ThriftHiveMetastore.grant_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
compareTo(ThriftHiveMetastore.grant_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
compareTo(ThriftHiveMetastore.heartbeat_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
compareTo(ThriftHiveMetastore.heartbeat_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
compareTo(ThriftHiveMetastore.heartbeat_txn_range_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
compareTo(ThriftHiveMetastore.heartbeat_txn_range_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
compareTo(ThriftHiveMetastore.isPartitionMarkedForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
compareTo(ThriftHiveMetastore.isPartitionMarkedForEvent_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
compareTo(ThriftHiveMetastore.list_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
compareTo(ThriftHiveMetastore.list_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
compareTo(ThriftHiveMetastore.list_roles_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
compareTo(ThriftHiveMetastore.list_roles_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
compareTo(ThriftHiveMetastore.lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
compareTo(ThriftHiveMetastore.lock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
compareTo(ThriftHiveMetastore.markPartitionForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
compareTo(ThriftHiveMetastore.markPartitionForEvent_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
compareTo(ThriftHiveMetastore.open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
compareTo(ThriftHiveMetastore.open_txns_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
compareTo(ThriftHiveMetastore.partition_name_has_valid_characters_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
compareTo(ThriftHiveMetastore.partition_name_has_valid_characters_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
compareTo(ThriftHiveMetastore.partition_name_to_spec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
compareTo(ThriftHiveMetastore.partition_name_to_spec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
compareTo(ThriftHiveMetastore.partition_name_to_vals_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
compareTo(ThriftHiveMetastore.partition_name_to_vals_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
compareTo(ThriftHiveMetastore.rename_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
compareTo(ThriftHiveMetastore.rename_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
compareTo(ThriftHiveMetastore.renew_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
compareTo(ThriftHiveMetastore.renew_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
compareTo(ThriftHiveMetastore.revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
compareTo(ThriftHiveMetastore.revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
compareTo(ThriftHiveMetastore.revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
compareTo(ThriftHiveMetastore.revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
compareTo(ThriftHiveMetastore.set_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
compareTo(ThriftHiveMetastore.set_aggr_stats_for_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
compareTo(ThriftHiveMetastore.set_ugi_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
compareTo(ThriftHiveMetastore.set_ugi_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
compareTo(ThriftHiveMetastore.setMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
compareTo(ThriftHiveMetastore.setMetaConf_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
compareTo(ThriftHiveMetastore.show_compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
compareTo(ThriftHiveMetastore.show_compact_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
compareTo(ThriftHiveMetastore.show_locks_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
compareTo(ThriftHiveMetastore.show_locks_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
compareTo(ThriftHiveMetastore.unlock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
compareTo(ThriftHiveMetastore.unlock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
compareTo(ThriftHiveMetastore.update_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
compareTo(ThriftHiveMetastore.update_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
compareTo(ThriftHiveMetastore.update_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
compareTo(ThriftHiveMetastore.update_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
compareTo(TxnAbortedException) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
compareTo(TxnInfo) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
compareTo(TxnOpenException) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
compareTo(Type) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
compareTo(UnknownDBException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
compareTo(UnknownPartitionException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
compareTo(UnknownTableException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
compareTo(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
compareTo(Version) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
compareTo(CompactionInfo) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
Compares two ByteWritables.
compareTo(AcidUtils.ParsedDelta) - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
compareTo(OrcFileKeyWrapper) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
compareTo(OrcFileValueWrapper) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
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(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
compareTo(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
compareTo(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
compareTo(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
compareTo(QueryPlan) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
compareTo(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
compareTo(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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(SparkWork.Dependency) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
compareTo(TezWork.Dependency) - Method in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
compareTo(HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
compareTo(HivePrivilege) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
compareTo(HivePrivilegeObject) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
compareTo(HiveRoleGrant) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
compareTo(InnerStruct) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
compareTo(ThriftTestObj) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
compareTo(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
compareTo(BytesRefWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
compareTo(DateWritable) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
compareTo(HiveCharWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
compareTo(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
compareTo(HiveIntervalDayTimeWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
compareTo(HiveIntervalYearMonthWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
compareTo(HiveVarcharWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
compareTo(Object) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
compareTo(TimestampWritable) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
compareTo(Complex) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
compareTo(IntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
compareTo(MegaStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
compareTo(MiniStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
compareTo(PropValueUnion) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
compareTo(SetIntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
compareTo(HiveClusterStatus) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
compareTo(HiveServerException) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
compareTo(ThriftHive.clean_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
compareTo(ThriftHive.clean_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
compareTo(ThriftHive.execute_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
compareTo(ThriftHive.execute_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
compareTo(ThriftHive.fetchAll_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
compareTo(ThriftHive.fetchAll_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
compareTo(ThriftHive.fetchN_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
compareTo(ThriftHive.fetchN_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
compareTo(ThriftHive.fetchOne_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
compareTo(ThriftHive.fetchOne_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
compareTo(ThriftHive.getClusterStatus_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
compareTo(ThriftHive.getClusterStatus_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
compareTo(ThriftHive.getQueryPlan_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
compareTo(ThriftHive.getQueryPlan_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
compareTo(ThriftHive.getSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
compareTo(ThriftHive.getSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
compareTo(ThriftHive.getThriftSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
compareTo(ThriftHive.getThriftSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
compareTo(Object) - Method in class org.apache.hadoop.hive.shims.CombineHiveKey
 
compareTo(TArrayTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
compareTo(TBinaryColumn) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
compareTo(TBoolColumn) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
compareTo(TBoolValue) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
compareTo(TByteColumn) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
compareTo(TByteValue) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
compareTo(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
compareTo(TCancelDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
compareTo(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
compareTo(TCancelOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
compareTo(TCLIService.CancelDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
compareTo(TCLIService.CancelDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
compareTo(TCLIService.CancelOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
compareTo(TCLIService.CancelOperation_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
compareTo(TCLIService.CloseOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
compareTo(TCLIService.CloseOperation_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
compareTo(TCLIService.CloseSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
compareTo(TCLIService.CloseSession_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
compareTo(TCLIService.ExecuteStatement_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
compareTo(TCLIService.ExecuteStatement_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
compareTo(TCLIService.FetchResults_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
compareTo(TCLIService.FetchResults_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
compareTo(TCLIService.GetCatalogs_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
compareTo(TCLIService.GetCatalogs_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
compareTo(TCLIService.GetColumns_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
compareTo(TCLIService.GetColumns_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
compareTo(TCLIService.GetDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
compareTo(TCLIService.GetDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
compareTo(TCLIService.GetFunctions_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
compareTo(TCLIService.GetFunctions_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
compareTo(TCLIService.GetInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
compareTo(TCLIService.GetInfo_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
compareTo(TCLIService.GetOperationStatus_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
compareTo(TCLIService.GetOperationStatus_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
compareTo(TCLIService.GetResultSetMetadata_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
compareTo(TCLIService.GetResultSetMetadata_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
compareTo(TCLIService.GetSchemas_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
compareTo(TCLIService.GetSchemas_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
compareTo(TCLIService.GetTables_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
compareTo(TCLIService.GetTables_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
compareTo(TCLIService.GetTableTypes_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
compareTo(TCLIService.GetTableTypes_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
compareTo(TCLIService.GetTypeInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
compareTo(TCLIService.GetTypeInfo_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
compareTo(TCLIService.OpenSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
compareTo(TCLIService.OpenSession_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
compareTo(TCLIService.RenewDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
compareTo(TCLIService.RenewDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
compareTo(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
compareTo(TCloseOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
compareTo(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
compareTo(TCloseSessionResp) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
compareTo(TColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
compareTo(TColumnDesc) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
compareTo(TColumnValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
compareTo(TDoubleColumn) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
compareTo(TDoubleValue) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
compareTo(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
compareTo(TExecuteStatementResp) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
compareTo(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
compareTo(TFetchResultsResp) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
compareTo(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
compareTo(TGetCatalogsResp) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
compareTo(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
compareTo(TGetColumnsResp) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
compareTo(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
compareTo(TGetDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
compareTo(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
compareTo(TGetFunctionsResp) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
compareTo(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
compareTo(TGetInfoResp) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
compareTo(TGetInfoValue) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
compareTo(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
compareTo(TGetOperationStatusResp) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
compareTo(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
compareTo(TGetResultSetMetadataResp) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
compareTo(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
compareTo(TGetSchemasResp) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
compareTo(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
compareTo(TGetTablesResp) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
compareTo(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
compareTo(TGetTableTypesResp) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
compareTo(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
compareTo(TGetTypeInfoResp) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
compareTo(THandleIdentifier) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
compareTo(TI16Column) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
compareTo(TI16Value) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
compareTo(TI32Column) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
compareTo(TI32Value) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
compareTo(TI64Column) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
compareTo(TI64Value) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
compareTo(TMapTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
compareTo(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
compareTo(TOpenSessionResp) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
compareTo(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
compareTo(TPrimitiveTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
compareTo(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
compareTo(TRenewDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
compareTo(TRow) - Method in class org.apache.hive.service.cli.thrift.TRow
 
compareTo(TRowSet) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
compareTo(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
compareTo(TStatus) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
compareTo(TStringColumn) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
compareTo(TStringValue) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
compareTo(TStructTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
compareTo(TTableSchema) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
compareTo(TTypeDesc) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
compareTo(TTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
compareTo(TTypeQualifiers) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
compareTo(TTypeQualifierValue) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
compareTo(TUnionTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
compareTo(TUserDefinedTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
compareToInternal(RecordIdentifier) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
compareToScaleTen(UnsignedInt128, short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Compares with the given object after scaling up/down it for 10**scaleUp.
compareType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
compareTypes(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Compares two types identified by the given object inspectors.
compareUnsignedInt(int, int) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
If we can assume JDK 1.8, this should use java.lang.Integer.compareUnsigned(), which will be replaced with intrinsics in JVM.
compareUnsignedLong(long, long) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
If we can assume JDK 1.8, this should use java.lang.Long.compareUnsigned(), which will be replaced with intrinsics in JVM.
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
 
CompleteBean - Class in org.apache.hive.hcatalog.templeton
CompleteBean - The results of an CompleteDelegator run.
CompleteBean() - Constructor for class org.apache.hive.hcatalog.templeton.CompleteBean
 
CompleteBean(String) - Constructor for class org.apache.hive.hcatalog.templeton.CompleteBean
Create a new CompleteBean
completed - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
CompleteDelegator - Class in org.apache.hive.hcatalog.templeton
Complete a job.
CompleteDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.CompleteDelegator
 
completeInitializationOp(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
completeInitializationOp(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
This metod can be used to retrieve the results from async operations started at init time - before the operator pipeline is started.
completeJob(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Notify on a completed job.
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
Complex - Class in org.apache.hadoop.hive.serde2.thrift.test
 
Complex() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
Complex(int, String, List<Integer>, List<String>, List<IntString>, Map<String, String>, Map<String, Map<String, Map<String, PropValueUnion>>>, PropValueUnion, PropValueUnion, PropValueUnion) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
Complex(Complex) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.Complex
Performs a deep copy on other.
Complex._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
COMPLEX_TYPES - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
Complexpb - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.Complex - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.Complex(int, String, List<Integer>, List<String>, List<Complexpb.IntString>) - Constructor for class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
Complexpb.IntString - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.IntString(int, String, int) - Constructor for class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
complexSplit(String, Pattern) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Split the line based on a complex regex pattern.
componentize(PTFInvocationSpec) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
COMPOSITE_ROWID_CLASS - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
COMPOSITE_ROWID_FACTORY - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
CompositeAccumuloRowIdFactory<T extends AccumuloCompositeRowId> - Class in org.apache.hadoop.hive.accumulo.serde
AccumuloRowIdFactory designed for injection of the AccumuloCompositeRowId to be used to generate the Accumulo rowId.
CompositeAccumuloRowIdFactory(Class<T>) - Constructor for class org.apache.hadoop.hive.accumulo.serde.CompositeAccumuloRowIdFactory
 
CompositeHBaseKeyFactory<T extends HBaseCompositeKey> - Class in org.apache.hadoop.hive.hbase
 
CompositeHBaseKeyFactory(Class<T>) - Constructor for class org.apache.hadoop.hive.hbase.CompositeHBaseKeyFactory
 
CompositePartitionSpecProxy - Class in org.apache.hadoop.hive.metastore.partition.spec
Implementation of PartitionSpecProxy that composes a list of PartitionSpecProxy.
CompositePartitionSpecProxy(List<PartitionSpec>) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
CompositePartitionSpecProxy(String, String, List<PartitionSpec>) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
CompositePartitionSpecProxy.Iterator - Class in org.apache.hadoop.hive.metastore.partition.spec
Iterator to iterate over all Partitions, across all PartitionSpecProxy instances within the Composite.
CompositePartitionSpecProxy.Iterator(CompositePartitionSpecProxy) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
CompositeProcessor - Class in org.apache.hadoop.hive.ql.lib
CompositeProcessor.
CompositeProcessor(NodeProcessor...) - Constructor for class org.apache.hadoop.hive.ql.lib.CompositeProcessor
 
CompositeService - Class in org.apache.hive.service
CompositeService.
CompositeService(String) - Constructor for class org.apache.hive.service.CompositeService
 
CompositeService.CompositeServiceShutdownHook - Class in org.apache.hive.service
JVM Shutdown hook for CompositeService which will stop the given CompositeService gracefully in case of JVM shutdown.
CompositeService.CompositeServiceShutdownHook(CompositeService) - Constructor for class org.apache.hive.service.CompositeService.CompositeServiceShutdownHook
 
compress(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.CompressionCodec
Compress the in buffer to the out buffer.
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.
compressedKeyLength - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
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.
COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
COMPRESSIONBLOCKSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
CompressionCodec - Interface in org.apache.hadoop.hive.ql.io.orc
 
CompressionCodec.Modifier - Enum in org.apache.hadoop.hive.ql.io.orc
 
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.
compressionKind - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
CompressionUtils - Class in org.apache.hadoop.hive.common
This class contains methods used for the purposes of compression, this class should not be accessed from code run in Hadoop.
CompressionUtils() - Constructor for class org.apache.hadoop.hive.common.CompressionUtils
 
computeBucketMapJoinCPUCost(ImmutableList<Double>, ImmutableBitSet) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeBucketMapJoinIOCost(ImmutableList<Pair<Double, Double>>, ImmutableBitSet, int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeCardinalityBasedCost(HiveRelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeKeys(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the key as a standard object.
computeMapJoinCPUCost(ImmutableList<Double>, ImmutableBitSet) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeMapJoinIOCost(ImmutableList<Pair<Double, Double>>, ImmutableBitSet, int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
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.
computeMurmurHash(HiveKey) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
computePartitionList(HiveConf, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
computeScanCost(double, double) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
Model cost of join as size of Inputs.
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveLimit
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
computeSMBMapJoinCPUCost(ImmutableList<Double>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSMBMapJoinIOCost(ImmutableList<Pair<Double, Double>>, ImmutableBitSet, int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSortCPUCost(Double) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSortIOCost(Pair<Double, Double>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSortMergeCPUCost(ImmutableList<Double>, ImmutableBitSet) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
computeSortMergeIOCost(ImmutableList<Pair<Double, Double>>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
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.
ConcurrentScheduler - Class in org.apache.hive.testutils.junit.runners.model
Originally taken from com.google.code.tempusfugit.concurrency.ConcurrentScheduler
ConcurrentScheduler(ExecutorService) - Constructor for class org.apache.hive.testutils.junit.runners.model.ConcurrentScheduler
 
ConcurrentScheduler(ExecutorService, OutputStream) - Constructor for class org.apache.hive.testutils.junit.runners.model.ConcurrentScheduler
 
ConcurrentTestRunner - Class in org.apache.hive.testutils.junit.runners
Originally taken from com.google.code.tempusfugit.concurrency.ConcurrentTestRunner
ConcurrentTestRunner(Class<?>) - Constructor for class org.apache.hive.testutils.junit.runners.ConcurrentTestRunner
 
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
 
condn - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
conds - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
conds - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
conf - Variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
conf - Variable in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
conf - Variable in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
conf - Variable in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
conf - Variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
conf - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
conf - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
conf - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
conf - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
conf - Variable in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
conf - Variable in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
conf - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
conf - Variable in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
conf - Variable in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
conf - Variable in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
conf - Variable in class org.apache.hadoop.hive.ql.session.SessionState
current configuration.
conf - Variable in class org.apache.hive.hcatalog.data.transfer.HCatReader
 
conf - Variable in class org.apache.hive.hcatalog.data.transfer.HCatWriter
 
conf - Variable in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
CONF_ACID_KEY - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
CONF_LABEL_HCAT_MESSAGE_FACTORY_IMPL_PREFIX - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
CONF_LABEL_HCAT_MESSAGE_FORMAT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
CONF_MAPREDUCE_JOB_CREDENTIALS_BINARY - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
config(String) - Method in class org.apache.hive.beeline.Commands
 
ConfigChangeEvent - Class in org.apache.hadoop.hive.metastore.events
 
ConfigChangeEvent(HiveMetaStore.HMSHandler, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.events.ConfigChangeEvent
 
configErrors - Variable in class org.apache.hadoop.hive.serde2.AbstractSerDe
 
ConfigurableTProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that need to have properties passed in to initialize them.
configuration - Variable in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
configure(JobConf, Instance, Connector, AccumuloConnectionParameters, ColumnMapper, List<IteratorSetting>, Collection<Range>) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
Configure the underlying AccumuloInputFormat
configure(JobConf) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
configure(JobConf) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat.Base64RecordWriter
 
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.merge.MergeFileMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat
 
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
 
configure() - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.JobConfigurer
Configure the job with the multiple output formats added.
configure() - Method in class org.apache.hive.hcatalog.templeton.WadlConfig
 
configureAccumuloOutputFormat(JobConf) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
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).
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
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).
configureJob(Configuration, String, Path) - Static method in class org.apache.hadoop.hive.hbase.HBaseTableSnapshotInputFormatUtil
Configures conf for the snapshot job.
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hadoop.hive.hbase.CompositeHBaseKeyFactory
 
configureJobConf(TableDesc, JobConf) - Method in interface org.apache.hadoop.hive.hbase.HBaseKeyFactory
configure jobConf for this factory
configureJobConf(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
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(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
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
 
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
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.accumulo.AccumuloStorageHandler
 
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
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).
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
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).
configureOutputStorageHandler(HiveStorageHandler, Configuration, OutputJobInfo) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
configureOutputStorageHandler(JobContext, OutputJobInfo, Map<String, String>) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
Configure the output storage handler, with allowing specification of partvals from which it picks the dynamic partvals
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
Push down table properties into the JobConf.
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
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.
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
ConfigValSecurityException - Exception in org.apache.hadoop.hive.metastore.api
 
ConfigValSecurityException() - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
ConfigValSecurityException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
ConfigValSecurityException(ConfigValSecurityException) - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Performs a deep copy on other.
ConfigValSecurityException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
confLookupNeeded - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseArithmetic
 
confLookupNeeded - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
confOverlay - Variable in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
conn - Variable in class org.apache.hive.hcatalog.listener.NotificationListener
 
connect(Configuration, Task) - Method in class org.apache.hadoop.hive.hbase.HBaseStatsAggregator
Does the necessary HBase initializations.
connect(Configuration) - Method in class org.apache.hadoop.hive.hbase.HBaseStatsPublisher
Does the necessary HBase initializations.
connect(SparkTran, SparkTran) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
Connects the two SparkTrans in the graph.
connect(BaseWork, BaseWork, SparkEdgeProperty) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
connect adds an edge between a and b.
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.CounterStatsAggregatorSpark
 
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.
connect(String) - Method in class org.apache.hive.beeline.Commands
 
connect(Properties) - Method in class org.apache.hive.beeline.Commands
 
connect(String, Properties) - Method in class org.apache.hive.jdbc.HiveDriver
 
connectedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
Connection - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
Connection(String, Vertex) - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.Connection
 
ConnectionError - Exception in org.apache.hive.hcatalog.streaming
 
ConnectionError(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.ConnectionError
 
ConnectionError(HiveEndPoint, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.ConnectionError
 
ConnectionFailureException - Exception in org.apache.hive.hcatalog.api
Class representing exceptions resulting from connection problems between HCat client and server.
ConnectionFailureException(String, Throwable) - Constructor for exception org.apache.hive.hcatalog.api.ConnectionFailureException
 
connectionParams - Variable in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
connectLeadLagFunctionsToPartition(PTFDesc, PTFPartition.PTFPartitionIterator<Object>) - Static method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
connectWithRetry(String, long, 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 - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
console - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
console - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
console - Variable in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
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
 
Const() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
CONST_VAL - Static variable in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
constant() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
constant() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
ConstantObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
ConstantObjectInspector.
ConstantPropagate - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based optimization steps.
ConstantPropagate() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagate
 
ConstantPropagate(ConstantPropagateProcCtx.ConstantPropagateOption) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagate
 
ConstantPropagate.ConstantPropagateWalker - Class in org.apache.hadoop.hive.ql.optimizer
Walks the op tree in root first order.
ConstantPropagate.ConstantPropagateWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagate.ConstantPropagateWalker
 
ConstantPropagateProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
This class implements the processor context for Constant Propagate.
ConstantPropagateProcCtx() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
ConstantPropagateProcCtx(ConstantPropagateProcCtx.ConstantPropagateOption) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
ConstantPropagateProcCtx.ConstantPropagateOption - Enum in org.apache.hadoop.hive.ql.optimizer
 
ConstantPropagateProcFactory - Class in org.apache.hadoop.hive.ql.optimizer
Factory for generating the different node processors used by ConstantPropagate.
ConstantPropagateProcFactory.ConstantPropagateDefaultProc - Class in org.apache.hadoop.hive.ql.optimizer
The Default Node Processor for Constant Propagation.
ConstantPropagateProcFactory.ConstantPropagateDefaultProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateDefaultProc
 
ConstantPropagateProcFactory.ConstantPropagateFileSinkProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for constant propagation for FileSink Operators.
ConstantPropagateProcFactory.ConstantPropagateFileSinkProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateFileSinkProc
 
ConstantPropagateProcFactory.ConstantPropagateFilterProc - Class in org.apache.hadoop.hive.ql.optimizer
Node Processor for Constant Propagation on Filter Operators.
ConstantPropagateProcFactory.ConstantPropagateFilterProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateFilterProc
 
ConstantPropagateProcFactory.ConstantPropagateGroupByProc - Class in org.apache.hadoop.hive.ql.optimizer
Node Processor for Constant Propagate for Group By Operators.
ConstantPropagateProcFactory.ConstantPropagateGroupByProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateGroupByProc
 
ConstantPropagateProcFactory.ConstantPropagateJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Constant Propagation for Join Operators.
ConstantPropagateProcFactory.ConstantPropagateJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateJoinProc
 
ConstantPropagateProcFactory.ConstantPropagateReduceSinkProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Constant Propagation for ReduceSink Operators.
ConstantPropagateProcFactory.ConstantPropagateReduceSinkProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateReduceSinkProc
 
ConstantPropagateProcFactory.ConstantPropagateSelectProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Constant Propagation for Select Operators.
ConstantPropagateProcFactory.ConstantPropagateSelectProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateSelectProc
 
ConstantPropagateProcFactory.ConstantPropagateStopProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Constant Propagation for Operators which is designed to stop propagate.
ConstantPropagateProcFactory.ConstantPropagateStopProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateStopProc
 
ConstantPropagateProcFactory.ConstantPropagateTableScanProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Constant Propagation for Table Scan Operators.
ConstantPropagateProcFactory.ConstantPropagateTableScanProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateTableScanProc
 
Constants - Class in org.apache.hadoop.hive.serde
Deprecated.
Constants() - Constructor for class org.apache.hadoop.hive.serde.Constants
Deprecated.
 
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, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
ConstListContents() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
ConstMap() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
ConstMapContents() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
constructJoinPredicateInfo(Join) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
constructJoinPredicateInfo(MultiJoin) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
constructJoinPredicateInfo(Join, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
constructJoinPredicateInfo(MultiJoin, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
constructJoinPredicateInfo(List<RelNode>, List<RelDataTypeField>, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
constructListBucketingCtx(List<String>, List<List<String>>, Map<List<String>, String>, boolean, HiveConf) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Construct list bucketing context.
constructVectorizedRowBatch(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Create VectorizedRowBatch from ObjectInspector
constructVectorizedRowBatch(StructObjectInspector, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Create VectorizedRowBatch from key and value object inspectors
ConstValue() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
consumeBuffer(int) - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
containerDirectAccess - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
contains(byte[], int, int, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMultiSet
 
contains(byte[], int, int, VectorMapJoinHashSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashSet
 
contains(long, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet
 
contains(long, VectorMapJoinHashSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet
 
contains(byte[], int, int, VectorMapJoinHashMultiSetResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinBytesHashMultiSet
 
contains(byte[], int, int, VectorMapJoinHashSetResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinBytesHashSet
 
contains(long, VectorMapJoinHashMultiSetResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashMultiSet
 
contains(long, VectorMapJoinHashSetResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashSet
 
contains(byte[], int, int, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet
 
contains(byte[], int, int, VectorMapJoinHashSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet
 
contains(long, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMultiSet
 
contains(long, VectorMapJoinHashSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashSet
 
contains(byte[], int, int, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashMultiSet
 
contains(byte[], int, int, VectorMapJoinHashSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashSet
 
contains(FileSplit) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexResult
 
contains(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
Whether the specified BaseWork is a vertex in this graph
containsAllFastStats(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
containsOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOutputMapping
 
containsPartitionColumnsOnly(ImmutableBitSet) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
containsPredicate(ExprNodeDesc, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
return true if predicate is already included in source
containsVar(String) - Static method in class org.apache.hadoop.hive.conf.SystemVariables
 
CONTENTLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
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.
CONTEXT_NAME_KEY - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
contextDestroyed(ServletContextEvent) - Method in class org.apache.hadoop.hive.hwi.HWIContextListener
When the Hive Web Interface is closing we locate the Runnable HiveSessionManager and set it's internal goOn variable to false.
contextInitialized(ServletContextEvent) - Method in class org.apache.hadoop.hive.hwi.HWIContextListener
The Hive Web Interface manages multiple hive sessions.
controllerAMChildOpts() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
controllerMRChildOpts() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
CONVENTION - Static variable in interface org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveRelNode
Calling convention for relational operations that occur in Hive.
conversionHelper - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
ConversionTreeReaderFactory - Class in org.apache.hadoop.hive.ql.io.orc
Factory for creating ORC tree readers.
ConversionTreeReaderFactory() - Constructor for class org.apache.hadoop.hive.ql.io.orc.ConversionTreeReaderFactory
 
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(DecimalColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
Convert input decimal value to a decimal with a possibly different precision and scale, at position i in the respective vectors.
convert(Binary) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
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.calcite.translator.ASTConverter
 
convert(RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverter
 
convert(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
convert(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
convert(ExprNodeConstantDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
convert(RelOptCluster, ExprNodeDesc, List<RelNode>, LinkedHashMap<RelNode, RowResolver>, Map<RelNode, ImmutableMap<String, Integer>>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
convert(TypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(PrimitiveTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(ListTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(MapTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(StructTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(UnionTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convert(List<String>, List<TypeInfo>, List<String>, String, String, String) - Method in class org.apache.hadoop.hive.serde2.avro.TypeInfoToSchema
Converts Hive schema to avro schema
convert(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.Converter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.IdentityConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.ListConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.MapConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.StructConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.UnionConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.BinaryConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.BooleanConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.ByteConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.DateConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.DoubleConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.FloatConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveCharConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveDecimalConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveIntervalDayTimeConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveIntervalYearMonthConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveVarcharConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.IntConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.LongConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.ShortConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.StringConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TextConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TimestampConverter
 
convertBucketMapJoinToSMBJoin(MapJoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
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
 
convertedParameters - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer.GenericUDAFInfo
 
converter - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
converter0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
converter1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
converterFormat - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPrintf
 
converterLeft - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
converterRight - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
convertExprToFilter(byte[]) - Method in interface org.apache.hadoop.hive.metastore.PartitionExpressionProxy
Converts serialized Hive expression into filter in the format suitable for Filter.g.
convertExprToFilter(byte[]) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore
 
convertGroupByMapSideSortedGroupBy(HiveConf, GroupByOperator, int) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
convertIdentifierPattern(String, boolean) - Method in class org.apache.hive.service.cli.operation.MetadataOperation
Convert wildchars and escape sequence from JDBC format to datanucleous/regex
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
 
convertIfNecessary(Object, ObjectInspector, boolean) - 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
 
convertJoinMapJoin(JoinOperator, OptimizeSparkProcContext, int) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkMapJoinOptimizer
 
convertJoinOpMapJoinOp(HiveConf, JoinOperator, boolean, String[], List<String>, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
convertJoinToBucketMapJoin(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
convertJoinToSMBJoin(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
convertJoinToSMBJoinAndReturn(JoinOperator, SortBucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinOptimizer
 
convertListType(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convertMapJoin(HiveConf, JoinOperator, boolean, String[], List<String>, int, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
convert a regular join to a a map-side join.
convertMapJoin(HiveConf, JoinOperator, boolean, String[], List<String>, int, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.SparkMapJoinProcessor
convert a regular join to a a map-side join.
convertMapJoinToBucketMapJoin(MapJoinOperator, BucketJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
convertMapType(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convertOpTree(RelNode, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForASTConv
 
convertOpTree(RelNode, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForReturnPath
 
convertPrimitiveToDouble(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Convert a primitive object to double.
convertPrimitiveType(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convertRowBatchBlobToVectorizedBatch(Object, int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Deserialized set of rows and populates the batch
convertSchemaPattern(String) - Method in class org.apache.hive.service.cli.operation.MetadataOperation
Convert wildchars and escape sequence of schema pattern from JDBC format to datanucleous/regex The schema pattern treats empty string also as wildchar
convertSMBJoinToMapJoin(HiveConf, SMBMapJoinOperator, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
convert a sortmerge join to a a map-side join.
convertStructType(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
convertTimestampToBytes(Timestamp, byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
Writes a Timestamp's serialized value to byte array b at the given offset
convertToArray(Map<Byte, T>, Class<T>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
convertToMPartitionColumnStatistics(MPartition, ColumnStatisticsDesc, ColumnStatisticsObj) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
convertToMTableColumnStatistics(MTable, ColumnStatisticsDesc, ColumnStatisticsObj) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
convertToStandardStructObjectInspector(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
convertToString(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Convert a UTF-8 byte array to String.
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
 
CookieSigner - Class in org.apache.hive.service
The cookie signer generates a signature based on SHA digest and appends it to the cookie value generated at the server side.
CookieSigner(byte[]) - Constructor for class org.apache.hive.service.CookieSigner
Constructor
cOpKeyset() - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
copy(FileSystem, Path, FileSystem, Path, boolean, boolean, HiveConf) - Static method in class org.apache.hadoop.hive.common.FileUtils
Copies files between filesystems.
copy() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
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.exec.persistence.UnwrapRowContainer
 
copy() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveLimit
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
copy(RelTraitSet, RelNode, RelDistribution, RelCollation) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
copy(RelDataType) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
Copy TableScan operator with a new Row Schema.
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion
 
copy(RelDataType) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
copy() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
copy(HCatRecord) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
copy(HCatRecord) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
copy(HCatRecord) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
COPY_NAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
copyAndEscapeStringDataToText(byte[], int, int, byte, Text) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
copyByReference(VectorizedRowBatch, int, VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow
 
copyBytesWritable(BytesWritable) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
copyByValue(VectorizedRowBatch, int, VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow
 
copyConf(Configuration, Configuration) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Replace the contents of dest with the contents of src
copyFiles(HiveConf, Path, Path, FileSystem, boolean, boolean, List<Path>) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
Copy files.
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
copyGroupKey(VectorizedRowBatch, VectorizedRowBatch, DataOutputBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupKeyHelper
 
copyHiveKey(HiveKey) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
copyJobPropertiesToJobConf(Map<String, String>, JobConf) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
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
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBinaryObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBooleanObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyByteObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDateObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDoubleObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyFloatObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveDecimalObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveIntervalDayTimeObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveIntervalYearMonthObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyIntObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyLongObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyShortObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyVoidObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBooleanObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDoubleObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableFloatObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableIntObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableLongObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableShortObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
copyObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableVoidObjectInspector
 
copyObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Get a copy of the Object in the same class, so the return value can be stored independently of the parameter.
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
 
copyStructToArray(Object, ObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption, Object[], int) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
copyTableJobPropertiesToConf(TableDesc, Configuration) - 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.
copyTablePropertiesToConf(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Copies the storage handler proeprites 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
 
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
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.GenericUDFBaseArithmetic
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentDate
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
copyToStandardJavaObject(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
copyToStandardObject(Object[], ObjectInspector[], ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
copyToStandardObject(List<Object>, Object, StructObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Copy fields in the input row to the output array of standard objects.
copyToStandardObject(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Returns a deep copy of the Object o that can be scanned by a StandardObjectInspector returned by getStandardObjectInspector(oi).
copyToStandardObject(Object, ObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
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
 
CorrelationOptimizer.CorrelationNodeProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.correlation
 
CorrelationOptimizer.CorrelationNodeProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
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.
cost(Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.TypeRule
 
count - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMultiSetResult
 
count() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMultiSetResult
 
count() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult
 
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
 
COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
countAfterReport - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
CounterStatsAggregator - Class in org.apache.hadoop.hive.ql.stats
 
CounterStatsAggregator() - Constructor for class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
CounterStatsAggregatorSpark - Class in org.apache.hadoop.hive.ql.stats
 
CounterStatsAggregatorSpark() - Constructor for class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorSpark
 
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
 
countLockComponents(long) - Static method in class org.apache.hadoop.hive.metastore.txn.TxnDbUtil
A tool to count the number of partitions, tables, and databases locked by a particular lockId.
countNonNulls(long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
 
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.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
countNullsField - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
countNullsFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
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(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
create(T1, T2) - Static method in class org.apache.hadoop.hive.common.ObjectPair
Creates a pair.
create(BigDecimal) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(BigDecimal, boolean) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(BigInteger, int) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(String) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(BigInteger) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(int) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
create(long) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
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(Configuration, SerDe, StructObjectInspector, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
create(String, ByteBuffer[], long[], long, CompressionCodec, int) - Static method in class org.apache.hadoop.hive.ql.io.orc.InStream
Deprecated.
create(String, List<DiskRange>, long, CompressionCodec, int) - Static method in class org.apache.hadoop.hive.ql.io.orc.InStream
Create an input stream from a list of disk ranges with data.
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) - Static method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
create(String) - Static method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
create() - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
create(RelNode, List<? extends RexNode>, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
Creates a HiveProject with no sort keys.
create(RelOptCluster, RelNode, List<? extends RexNode>, RelDataType, List<RelCollation>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
Creates a HiveProject.
create(RelOptCluster, RelNode, List<? extends RexNode>, RelDataType, RelTraitSet, List<RelCollation>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
Creates a HiveProject.
create(RelNode, RelDistribution, RelCollation, ImmutableList<RexNode>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
Creates a HiveSortExchange.
create(Exception) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
Create CommandProcessorResponse object indicating an error.
create(Object, Class<T>, AuthorizationFactory.AuthorizationExceptionHandler) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationFactory
 
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
 
create(byte[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
create(BytesWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
create(boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
create(byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
create(Date) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
create(double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
create(float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
create(HiveChar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
create(byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
create(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
create(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
create(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
create(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
create(int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
create(long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
create(short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
create(Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
create(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
create(Timestamp) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
create(byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
create(byte[]) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBinaryObjectInspector
Create an object with the value.
create(BytesWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBinaryObjectInspector
Create an object with the value.
create(boolean) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBooleanObjectInspector
Create an object with the value.
create(byte) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableByteObjectInspector
Create an object with the value.
create(Date) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableDateObjectInspector
 
create(double) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableDoubleObjectInspector
Create an object with the value.
create(float) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableFloatObjectInspector
Create an object with the value.
create(HiveChar) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveCharObjectInspector
 
create(byte[], int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveDecimalObjectInspector
 
create(HiveDecimal) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveDecimalObjectInspector
 
create(HiveIntervalDayTime) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalDayTimeObjectInspector
 
create(HiveIntervalYearMonth) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalYearMonthObjectInspector
 
create(HiveVarchar) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveVarcharObjectInspector
 
create(int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableIntObjectInspector
Create an object with the value.
create(long) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableLongObjectInspector
Create an object with the value.
create(short) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableShortObjectInspector
Create an object with the value.
create(Text) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableStringObjectInspector
Create an object with the value.
create(String) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableStringObjectInspector
Create an object with the value.
create(byte[], int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableTimestampObjectInspector
 
create(Timestamp) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableTimestampObjectInspector
 
create(byte[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
create(BytesWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
create(boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBooleanObjectInspector
 
create(byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
create(Date) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
create(double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDoubleObjectInspector
 
create(float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableFloatObjectInspector
 
create(HiveChar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
create(byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
create(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
create(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
create(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
create(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
create(int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableIntObjectInspector
 
create(long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableLongObjectInspector
 
create(short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableShortObjectInspector
 
create(Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
create(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
create(byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
create(Timestamp) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
create(int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Create a list with the given size.
create() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Create an empty map.
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
Create a struct which is not null, but all its fields are null.
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableUnionObjectInspector
 
create(int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
create(String, String, String, Map<String, String>) - Static method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Deprecated.
create(HCatPartition) - Static method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Constructs a Builder instance, using an HCatPartition object.
create(Configuration) - Static method in class org.apache.hive.hcatalog.api.HCatClient
Creates an instance of HCatClient.
create(String) - Static method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Creates the builder for defining attributes.
create(String, String, List<HCatFieldSchema>) - Static method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
create(HCatTable, boolean) - Static method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Getter for HCatCreateTableDesc.Builder instance.
create(HCatTable) - Static method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Getter for HCatCreateTableDesc.Builder instance.
create(HCatClient, HCatNotificationEvent) - Method in class org.apache.hive.hcatalog.api.repl.exim.EximReplicationTaskFactory
 
create(HCatClient, HCatNotificationEvent) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Factory method to return appropriate subtype of ReplicationTask for given event
create(HCatClient, HCatNotificationEvent) - Method in interface org.apache.hive.hcatalog.api.repl.ReplicationTask.Factory
 
create(String, String, String, Properties) - Static method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Initializes a new InputJobInfo for reading data from a table.
create(String, String, Map<String, String>) - Static method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Initializes a new OutputJobInfo instance for writing data from a table.
create(String) - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Create a new map object from the existing json.
create() - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Create a new map object.
create() - Method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
Create the parent znode for this job state.
create(TempletonStorage.Type, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Create a node in ZooKeeper
create(TableSchema, TProtocolVersion) - Static method in class org.apache.hive.service.cli.RowSetFactory
 
create(TRowSet, TProtocolVersion) - Static method in class org.apache.hive.service.cli.RowSetFactory
 
create_database(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_database(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_database(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_database(Database) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_database(Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_function(Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_function_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_function(Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_function_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_function(Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_function(Function) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_function(Function) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_role(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_role(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_role(Role) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
create_role(Role) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
create_table(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_table(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_table(Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_table(Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_table_with_environment_context(Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_table_with_environment_context(Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_table_with_environment_context(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_table_with_environment_context(Table, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_table_with_environment_context(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_table_with_environment_context(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
create_table_with_environment_context(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
create_type(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_type(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_type(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_type(Type) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_type(Type) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
createAnalyzer(boolean) - Static method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
 
createArrayOf(String, Object[]) - Method in class org.apache.hive.jdbc.HiveConnection
 
createBlob() - Method in class org.apache.hive.jdbc.HiveConnection
 
createBucketFile(Path, int) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Create the bucket filename.
createBucketFiles(FileSinkOperator.FSPaths) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
createBucketForFileIdx(FileSinkOperator.FSPaths, int) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
createByteArray(BytesWritable) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
gets a byte[] with copy of data from source BytesWritable
createClient() - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
createClient(Map<String, String>, NioEventLoopGroup, String, int, String, String, RpcDispatcher) - Static method in class org.apache.hive.spark.client.rpc.Rpc
Creates an RPC client for a server running on the given remote host and port.
createClient(Map<String, String>, HiveConf) - Static method in class org.apache.hive.spark.client.SparkClientFactory
Instantiates a new Spark client.
createClientTransport(String, String, String, String, TTransport, Map<String, String>) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Client
Create a client-side SASL transport that wraps an underlying transport.
createClientWithConf(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
createClob() - Method in class org.apache.hive.jdbc.HiveConnection
 
createCodec(CompressionKind) - Static method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
createColumnarStructInspector(List<String>, List<TypeInfo>, byte[], Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createColumnarStructInspector(List<String>, List<TypeInfo>, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical ObjectInspector for ColumnarStruct with the given columnNames and columnTypeInfos.
createColumnarStructInspector(List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryFactory
 
createColumnsetSchema(String, List<String>, List<String>, Configuration) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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.
createConfigurer(Job) - Static method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
Get a JobConfigurer instance that will support configuration of the job for multiple output formats.
createConnection() - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Create the JMS connection
createConstructorMetaData(int, float) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
Creates metadata for implementation classes' ctors from threshold and load factor.
createConversionCast(ExprNodeDesc, PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
createCookieToken(String) - Static method in class org.apache.hive.service.auth.HttpAuthUtils
Creates and returns a HS2 cookie token.
createCounter(String, long) - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
createCounter(Enum<?>) - Method in class org.apache.hive.spark.counter.SparkCounters
 
createCounter(String, Enum<?>) - Method in class org.apache.hive.spark.counter.SparkCounters
 
createCounter(String, String) - Method in class org.apache.hive.spark.counter.SparkCounters
 
createCounter(String, String, long) - Method in class org.apache.hive.spark.counter.SparkCounters
 
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) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Create a new Database
createDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
createDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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.
createDatabase(HCatCreateDBDesc) - Method in class org.apache.hive.hcatalog.api.HCatClient
Creates the database.
createDatabase(HCatCreateDBDesc) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
createDatabase(String, DatabaseDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Create a database with the given name
createDatabase(String, DatabaseDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
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
 
CreateDatabaseEvent - Class in org.apache.hadoop.hive.metastore.events
 
CreateDatabaseEvent(Database, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.CreateDatabaseEvent
 
CreateDatabaseMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a Database is created in HCatalog.
CreateDatabaseMessage() - Constructor for class org.apache.hive.hcatalog.messaging.CreateDatabaseMessage
 
CreateDatabaseReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
CreateDatabaseReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.CreateDatabaseReplicationTask
 
createDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
createDummy() - Static method in class org.apache.hadoop.hive.ql.exec.Operator
 
createEdge(VertexGroup, JobConf, Vertex, TezEdgeProperty, TezWork.VertexType) - 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, Vertex, TezEdgeProperty, TezWork.VertexType) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Given two vertices and the configuration for the source vertex, createEdge will create an Edge object that connects the two.
createEncryptionZone(Path, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
createEncryptionZone(Path, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
create encryption zone by path and keyname
createEncryptionZone(Path, String) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
createError(String, int) - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Create a new map error object.
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCumeDist
 
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFDenseRank
 
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue
 
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue
 
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentRank
 
createEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopStreaming.NoopStreamingResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMapStreaming.NoopWithMapStreamingResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
createEvaluator(PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
createExportDump(FileSystem, Path, Table, Iterable<Partition>, ReplicationSpec) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
createField(int, String, ObjectInspector, String) - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
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
 
createFilter(Operator, ExprWalkerInfo, OpWalkerInfo) - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
createFilter(Operator, Map<String, List<ExprNodeDesc>>, OpWalkerInfo) - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
createFromConf(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
createFunction(Function) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
createFunction(Function) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
createFunction(Function) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createFunction(Function) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Register a user-defined function based on the function specification passed in.
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
 
createFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createGetter(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
createGetter(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
createGetter(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
createGetter(MapJoinKey) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
Creates reusable get adaptor that can be used to retrieve rows from the table based on either vectorized or non-vectorized input rows to MapJoinOperator.
createGetter(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
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
 
createHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMap
 
createHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashMap
 
createHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
createHashMapResult() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMap
 
createHashMapResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap
 
createHashMultiSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMultiSet
 
createHashMultiSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashMultiSet
 
createHashMultiSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet
 
createHashMultiSetResult() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMultiSet
 
createHashMultiSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet
 
createHashSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashSet
 
createHashSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashSet
 
createHashSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet
 
createHashSetResult() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashSet
 
createHashSetResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet
 
createHashTable(MapJoinDesc, MapJoinTableContainer) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedCreateHashTable
 
createHdfsEncryptionShim(FileSystem, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
createHdfsEncryptionShim(FileSystem, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
createHdfsEncryptionShim(FileSystem, Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Returns a new instance of the HdfsEncryption shim.
createHiveAuthorizer(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider, HiveAuthzSessionContext) - 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, HiveAuthzSessionContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory
 
createHiveAuthorizer(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider, HiveAuthzSessionContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizerFactory
 
createHiveDB(HiveConf) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
createHivePrivilegeObject(List<String>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
Create HivePrivilegeObject of type HivePrivilegeObjectType.COMMAND_PARAMS
createHiveSparkClient(HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.HiveSparkClientFactory
 
createIdentifier() - Method in class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
 
createIndex(Index, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
create an index
createIndex(Index, Table) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
create an index
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
 
createIndexStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createJobContext(Configuration, JobID) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createJobContext(JobConf, JobID, Progressable) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createJobContext(JobContext) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createJobContext(JobConf, JobID, Progressable) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createKey() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
createKey(ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.CompositeHBaseKeyFactory
 
createKey(ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
createKey(ObjectInspector) - Method in interface org.apache.hadoop.hive.hbase.HBaseKeyFactory
create custom object for hbase key
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
Deprecated.
 
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.OrcFileStripeMergeRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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
 
createKey(String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
createKey(String, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
Creates an encryption key.
createKey(String, int) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
createKey() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
createKeyObjectInspector(TypeInfo) - Method in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
createKeyObjectInspector(TypeInfo) - Method in interface org.apache.hadoop.hive.hbase.HBaseKeyFactory
create custom object inspector for hbase key
createLazyBinaryObject(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryFactory
Create a hierarchical LazyBinaryObject based on the given typeInfo.
createLazyBinaryPrimitiveClass(PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryFactory
Create a lazy binary primitive class given the type name.
createLazyBinarySerDe(Configuration, StructObjectInspector, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
createLazyField(int, StructField) - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloRow
 
createLazyField(ColumnMappings.ColumnMapping[], int, ObjectInspector) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
Create the lazy field
createLazyField(int, StructField) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseRow
 
createLazyField(int, StructField) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
createLazyHBaseStructInspector(LazySerDeParameters, int, HBaseKeyFactory, List<HBaseValueFactory>) - Static method in class org.apache.hadoop.hive.hbase.HBaseLazyObjectFactory
 
createLazyObject(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical LazyObject based on the given typeInfo.
createLazyObject(ObjectInspector, boolean) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Creates a LazyObject based on the LazyObjectInspector.
createLazyObjectBase(ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
 
createLazyObjectBase(ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
create the lazy object for this field
createLazyObjectBase(ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarStruct
 
createLazyObjectInspector(TypeInfo, byte[], int, Text, boolean, byte, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyObjectInspector(TypeInfo, byte[], int, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyObjectInspector(TypeInfo, byte[], int, Text, boolean, byte, boolean) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyObjectInspector(TypeInfo, byte[], int, Text, boolean, byte, boolean, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyObjectInspector(TypeInfo, int, LazyObjectInspectorParameters, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
createLazyPrimitiveBinaryClass(PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
 
createLazyPrimitiveClass(PrimitiveObjectInspector, boolean) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a lazy primitive object instance given a primitive object inspector based on it's type.
createLazyPrimitiveClass(PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a lazy primitive class given the type name.
createLazyStructInspector(List<String>, List<TypeInfo>, byte[], Text, boolean, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyStructInspector(List<String>, List<TypeInfo>, byte[], Text, boolean, boolean, byte, boolean) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Deprecated.
createLazyStructInspector(List<String>, List<TypeInfo>, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical ObjectInspector for LazyStruct with the given columnNames and columnTypeInfos.
createLLEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag
 
createLLEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead
 
createLLEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag
 
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
 
createMacroStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createMapTypeFieldSchema(String, PrimitiveTypeInfo, HCatSchema, String) - Static method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
createMapWork(GenTezProcContext, Operator<?>, TezWork, PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createMapWork(GenSparkProcContext, Operator<?>, SparkWork, PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
createMapWork(GenSparkProcContext, Operator<?>, SparkWork, PrunedPartitionList, boolean) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
createMergeTask(FileSinkDesc, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Create a block level merge task for RCFiles or stripe level merge task for ORCFiles
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
 
createNClob() - Method in class org.apache.hive.jdbc.HiveConnection
 
createObjectInspector(TypeInfo) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
createOperationLog() - Method in class org.apache.hive.service.cli.operation.Operation
 
createOutputMap() - Method in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
createOverlayedProperties(Properties, Properties) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Returns the union of table and partition properties, with partition properties taking precedence.
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
 
createPassword(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
Create the password and add it to shared store.
createPath(Table) - Method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
Creates path where partitions matching prefix should lie in filesystem
createPlanner(HiveConfigContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveVolcanoPlanner
 
createPool(JobConf, PathFilter...) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
createPool(JobConf, PathFilter...) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
createPreWarmVertex(TezConfiguration, int, Map<String, LocalResource>) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
createProducer(Destination) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Create a JMS producer
createPromise() - Method in class org.apache.hive.spark.client.rpc.Rpc
Creates a promise backed by this RPC's event loop.
createProxyFileSystem(FileSystem, URI) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
createProxyFileSystem(FileSystem, URI) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
createProxyFileSystem(FileSystem, URI) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Create a proxy file system that can serve a given scheme/authority using some other file system.
createProxyFileSystem(FileSystem, URI) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
createRCFileWriter(JobConf, FileSystem, Path, boolean, Progressable) - 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).
createReadBinaryResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadBinaryResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadBinaryResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadBinaryResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadDateResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadDateResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadDateResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadDateResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadDecimalResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadDecimalResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadDecimalResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadDecimalResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
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
 
createReadHiveCharResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadHiveCharResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadHiveCharResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadHiveCharResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadHiveVarcharResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadHiveVarcharResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadHiveVarcharResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadHiveVarcharResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadIntervalDayTimeResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadIntervalDayTimeResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadIntervalDayTimeResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadIntervalDayTimeResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadIntervalYearMonthResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadIntervalYearMonthResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadIntervalYearMonthResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadIntervalYearMonthResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadStringResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadStringResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadStringResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadStringResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createReadTimestampResults() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
createReadTimestampResults() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
createReadTimestampResults() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
createReadTimestampResults() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
Create the RecordReader for the given InputSplit.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hive.hcatalog.templeton.tool.SingleInputFormat
 
createReduceWork(GenTezProcContext, Operator<?>, TezWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createReduceWork(GenSparkProcContext, Operator<?>, SparkWork) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
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.HiveV1Authorizer
 
createRole(String, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
createRole(String, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
createRoleStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createRolling(Configuration, SerDe, StructObjectInspector, StructObjectInspector, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
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.contrib.util.typedbytes.TypedBytesRecordReader
 
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
 
createRowId(ObjectInspector) - Method in interface org.apache.hadoop.hive.accumulo.serde.AccumuloRowIdFactory
create custom object for accumulo
createRowId(ObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.CompositeAccumuloRowIdFactory
 
createRowId(ObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
createRowIdFactory(Configuration, Properties) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
createRowIdObjectInspector(TypeInfo) - Method in interface org.apache.hadoop.hive.accumulo.serde.AccumuloRowIdFactory
create custom object inspector for accumulo rowId
createRowIdObjectInspector(TypeInfo) - Method in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
createSampler(FetchWork, JobConf, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.hive.service.auth.PlainSaslServer.SaslPlainServerFactory
 
createSecret() - Method in class org.apache.hive.spark.client.rpc.RpcServer
Creates a secret for identifying a client connection.
createSelectListOI(MatchPath, PTFInputDef) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
createSelectListRR(MatchPath, PTFInputDef) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
createSequenceWriter(JobConf, FileSystem, Path, Class<?>, Class<?>, Progressable) - 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, Progressable) - 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).
createSerde(Table, HiveConf) - Method in class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
Creates LazySimpleSerde
createServer(String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
createSession(HWIAuth, String) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Here we handle creating the SessionItem, we do this for the JSP client because we need to set parameters the client is not aware of.
createSession(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
createSession() - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Creates a JMS session
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
 
createShowRolesTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createShowRolesTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createSourceInfo(TableDesc, ExprNodeDesc, String, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
createSpec(Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Table
Creates a partition name -> value spec map object
createSQLXML() - Method in class org.apache.hive.jdbc.HiveConnection
 
createStatement() - Method in class org.apache.hive.jdbc.HiveConnection
Creates a Statement object for sending SQL statements to the database.
createStatement(int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
createStatement(int, int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
createStruct(String, Object[]) - Method in class org.apache.hive.jdbc.HiveConnection
 
createSubjectAssumedTransport(String, TTransport, Map<String, String>) - Static method in class org.apache.hive.service.auth.KerberosSaslHelper
 
createTable(Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
createTable(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
createTable(Table) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
createTable(Table) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createTable(Table) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
createTable(String, List<String>, List<String>, Class<? extends InputFormat>, Class<?>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a table metadata 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 metadata and the directory for the table data
createTable(String, List<String>, List<String>, Class<? extends InputFormat>, Class<?>, int, List<String>, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Create a table metadata 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
createTable(HCatCreateTableDesc) - Method in class org.apache.hive.hcatalog.api.HCatClient
Creates the table.
createTable(HCatCreateTableDesc) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
createTable(String, String, TableDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Create a table.
createTable(String, String, TableDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
Create a new table.
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, 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, 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
 
CreateTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
CreateTableEvent(Table, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.CreateTableEvent
 
createTableLike(String, String, String, boolean, boolean, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Creates the table like an existing table.
createTableLike(String, String, String, boolean, boolean, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
createTableLike(String, String, TableLikeDesc) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Create a table like another.
createTableLike(String, String, String, TableLikeDesc) - Method in class org.apache.hive.hcatalog.templeton.Server
Create a new table like another table.
CreateTableLikeDesc - Class in org.apache.hadoop.hive.ql.plan
CreateTableLikeDesc.
CreateTableLikeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
CreateTableLikeDesc(String, boolean, boolean, String, String, String, String, Map<String, String>, Map<String, String>, boolean, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
CreateTableMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a table is created in HCatalog.
CreateTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.CreateTableMessage
 
CreateTableReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
CreateTableReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.CreateTableReplicationTask
 
createTables(Connection) - Static method in class org.apache.hive.testutils.jdbc.HiveBurnInClient
Creates 2 tables to query from
createTableSnapshotRegionSplit() - Static method in class org.apache.hadoop.hive.hbase.HBaseTableSnapshotInputFormatUtil
Create a bare TableSnapshotRegionSplit.
createTableStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createTaskAttemptContext(Configuration, TaskAttemptID) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createTaskAttemptContext(JobConf, TaskAttemptID, Progressable) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createTaskAttemptContext(TaskAttemptContext) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createTaskAttemptContext(JobConf, TaskAttemptID, Progressable) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createTaskAttemptID() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createTaskAttemptID(JobID, boolean, int, int) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
createTaskID() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
createTaskLocationHints(InputSplit[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.SplitGrouper
Create task location hints from a set of input splits
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
createTemporaryFile(Operator<? extends OperatorDesc>, Operator<? extends OperatorDesc>, Path, TableDesc, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Break the pipeline between parent and child, and then output data generated by parent to a temporary file stored in taskTmpDir.
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.
createTimestamp(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
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.
createTopic(String) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Get the topic object for the topicName
createTransportFactory(Map<String, String>) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
Create a TTransportFactory that, upon connection of a client socket, negotiates a Kerberized SASL transport.
createTreeReader(int, List<OrcProto.Type>, boolean[], boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.ConversionTreeReaderFactory
 
createTreeReader(int, Configuration, List<OrcProto.Type>, boolean[], boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderFactory
 
createTreeReader(int, List<OrcProto.Type>, boolean[], boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory
 
createType(Type) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
createType(Type) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createType(Type) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
createUnionWork(GenTezProcContext, Operator<?>, Operator<?>, TezWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createValidCompactTxnList(GetOpenTxnsInfoResponse) - Static method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
createValidReadTxnList(GetOpenTxnsResponse, long) - Static method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
createValue() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
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
Deprecated.
 
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.OrcFileStripeMergeRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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
 
createValue() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
createValueObject(ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
createValueObject(ObjectInspector) - Method in interface org.apache.hadoop.hive.hbase.struct.HBaseValueFactory
create custom object for hbase value
createValueObject(ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.struct.StructHBaseValueFactory
 
createValueObjectInspector(TypeInfo) - Method in class org.apache.hadoop.hive.hbase.struct.AvroHBaseValueFactory
 
createValueObjectInspector(TypeInfo) - Method in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
createValueObjectInspector(TypeInfo) - Method in interface org.apache.hadoop.hive.hbase.struct.HBaseValueFactory
create custom object inspector for the value
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, TezWork.VertexType) - 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
 
createViewStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
CrossMapEqualComparer - Class in org.apache.hadoop.hive.serde2.objectinspector
 
CrossMapEqualComparer() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.CrossMapEqualComparer
 
CrossProductCheck - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CrossProductCheck() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck
 
CrossProductCheck.ExtractReduceSinkInfo - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CrossProductCheck.MapJoinCheck - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CryptoProcessor - Class in org.apache.hadoop.hive.ql.processors
This class processes HADOOP commands used for HDFS encryption.
CryptoProcessor(HadoopShims.HdfsEncryptionShim, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.processors.CryptoProcessor
 
cteStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ctrlaCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
ctx - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.
cumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
CuratorFrameworkSingleton - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
CuratorFrameworkSingleton() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.CuratorFrameworkSingleton
 
curChar - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
currBigKeyTag - Variable in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
currCount - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
curReader - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
CURRENT - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
 
currentBytes() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
currentCtxs - Variable in class org.apache.hadoop.hive.ql.exec.MapOperator
 
currentDate - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentDate
 
currentKeys - Variable in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
currentLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
currentMapJoinOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentMapJoinOperators - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
currentMergeJoinOperator - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
CurrentNotificationEventId - Class in org.apache.hadoop.hive.metastore.api
 
CurrentNotificationEventId() - Constructor for class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
CurrentNotificationEventId(long) - Constructor for class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
CurrentNotificationEventId(CurrentNotificationEventId) - Constructor for class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
Performs a deep copy on other.
CurrentNotificationEventId._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
currentOffset() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
currentRootOperator - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentRootOperator - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
CurrentRowDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
CurrentRowDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef
 
currentScratchColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
currentServerContext - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
currentTask - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentTask - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
currentTimestamp - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
currentToken - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This is the last token that has been consumed successfully.
currentUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
currentUser - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
currentValueBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
CUSTOM_TEXT_SERDE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
CustomAuthenticationProviderImpl - Class in org.apache.hive.service.auth
This authentication provider implements the CUSTOM authentication.
CustomPartitionEdge - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomPartitionEdge(EdgeManagerPluginContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
CustomPartitionVertex - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomPartitionVertex(VertexManagerPluginContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
CustomPartitionVertex.PathComparatorForSplit - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomPartitionVertex.PathComparatorForSplit() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex.PathComparatorForSplit
 
CustomVertexConfiguration - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomVertexConfiguration() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
CustomVertexConfiguration(int, TezWork.VertexType) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
CustomVertexConfiguration(int, TezWork.VertexType, String, int) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 

D

DagUtils - Class in org.apache.hadoop.hive.ql.exec.tez
DagUtils.
data - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TimestampTreeReader
 
data - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
data - Variable in class org.apache.hive.jdbc.HiveMetaDataResultSet
 
DATA_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
DATA = 1;
database - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-database option if any that the session has been invoked with.
Database - Class in org.apache.hadoop.hive.metastore.api
 
Database() - Constructor for class org.apache.hadoop.hive.metastore.api.Database
 
Database(String, String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Database
 
Database(Database) - Constructor for class org.apache.hadoop.hive.metastore.api.Database
Performs a deep copy on other.
database - Variable in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
database - Variable in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
Database._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DATABASE_WAREHOUSE_SUFFIX - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
databaseComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DatabaseDesc - Class in org.apache.hive.hcatalog.templeton
A description of the database to create.
DatabaseDesc() - Constructor for class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
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.
databaseProperties(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc.Builder
Database properties.
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
 
dataDefinitionCausesTransactionCommit() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
dataDefinitionIgnoredInTransactions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
DataInputByteBuffer - Class in org.apache.hadoop.hive.ql.exec.tez
 
DataInputByteBuffer() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.DataInputByteBuffer
 
DataInputInputStream - Class in org.apache.hadoop.hive.hbase
 
DataInputInputStream(DataInput) - Constructor for class org.apache.hadoop.hive.hbase.DataInputInputStream
 
DATALENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
DataOutputOutputStream - Class in org.apache.hadoop.hive.hbase
 
DataOutputOutputStream(DataOutput) - Constructor for class org.apache.hadoop.hive.hbase.DataOutputOutputStream
 
DataReadMethod - Enum in org.apache.hive.spark.client.metrics
Method by which input data was read.
DataTransferFactory - Class in org.apache.hive.hcatalog.data.transfer
Use this factory to get instances of HCatReader or HCatWriter at master and slave nodes.
DataTransferFactory() - Constructor for class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
 
DataType - Class in org.apache.hive.hcatalog.data
 
DataType() - Constructor for class org.apache.hive.hcatalog.data.DataType
 
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, Map<String, String>) - 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 reads a ParquetWritable object and send the data to the Parquet API 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
 
Date - Class in org.apache.hadoop.hive.metastore.api
 
Date() - Constructor for class org.apache.hadoop.hive.metastore.api.Date
 
Date(long) - Constructor for class org.apache.hadoop.hive.metastore.api.Date
 
Date(Date) - Constructor for class org.apache.hadoop.hive.metastore.api.Date
Performs a deep copy on other.
DATE - Static variable in class org.apache.hive.hcatalog.data.DataType
 
Date._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DATE_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
DATE_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
DATE_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
DATE = 15;
DateColAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColAddIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
DateColAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
DateColAddIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColAddIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
DateColAddIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
DateColAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColAddIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
DateColAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
DateColAddIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColAddIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
DateColAddIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
DateColEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColEqualDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColEqualDateScalar
 
DateColEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColEqualDateScalar
 
DateColGreaterDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColGreaterDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterDateScalar
 
DateColGreaterDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterDateScalar
 
DateColGreaterEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColGreaterEqualDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterEqualDateScalar
 
DateColGreaterEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterEqualDateScalar
 
DateColLessDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColLessDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessDateScalar
 
DateColLessDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessDateScalar
 
DateColLessEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColLessEqualDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessEqualDateScalar
 
DateColLessEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessEqualDateScalar
 
DateColNotEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
DateColNotEqualDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColNotEqualDateScalar
 
DateColNotEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColNotEqualDateScalar
 
DateColSubtractDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColSubtractDateColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
DateColSubtractDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
DateColSubtractDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColSubtractDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
DateColSubtractDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
DateColSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColSubtractIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
DateColSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
DateColSubtractIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColSubtractIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
DateColSubtractIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
DateColSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColSubtractIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
DateColSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
DateColSubtractIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColSubtractIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
DateColSubtractIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
DateColSubtractTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
DateColSubtractTimestampColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
DateColSubtractTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
DateColSubtractTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
DateColSubtractTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
DateColSubtractTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
DateColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for DATE columns.
DateColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
DateColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
DateColumnStatsData(long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
DateColumnStatsData(DateColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Performs a deep copy on other.
DateColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DateLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
DateLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
dateLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dateLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DateObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A DateObjectInspector inspects an Object representing a Date.
dateResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dateResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
DateScalarAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
DateScalarAddIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
DateScalarAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
DateScalarAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert.txt.
DateScalarAddIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
DateScalarAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
DateScalarEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarEqualDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarEqualDateColumn
 
DateScalarEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarEqualDateColumn
 
DateScalarGreaterDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarGreaterDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterDateColumn
 
DateScalarGreaterDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterDateColumn
 
DateScalarGreaterEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarGreaterEqualDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterEqualDateColumn
 
DateScalarGreaterEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterEqualDateColumn
 
DateScalarLessDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarLessDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessDateColumn
 
DateScalarLessDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessDateColumn
 
DateScalarLessEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarLessEqualDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessEqualDateColumn
 
DateScalarLessEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessEqualDateColumn
 
DateScalarNotEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
DateScalarNotEqualDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarNotEqualDateColumn
 
DateScalarNotEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarNotEqualDateColumn
 
DateScalarSubtractDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
DateScalarSubtractDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
DateScalarSubtractDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
DateScalarSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
DateScalarSubtractIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
DateScalarSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
DateScalarSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert.txt.
DateScalarSubtractIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
DateScalarSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
DateScalarSubtractTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
DateScalarSubtractTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
DateScalarSubtractTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
DATESTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
dateStats(DateColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
DateString - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
DateString - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
DATETIME_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
DateTimeMath - Class in org.apache.hadoop.hive.ql.util
 
DateTimeMath() - Constructor for class org.apache.hadoop.hive.ql.util.DateTimeMath
 
dateToDays(Date) - Static method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
dateTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
dateTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
DateUtils - Class in org.apache.hive.common.util
DateUtils.
DateUtils() - Constructor for class org.apache.hive.common.util.DateUtils
 
dateWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDateResults
 
DateWritable - Class in org.apache.hadoop.hive.serde2.io
DateWritable Writable equivalent of java.sql.Date.
DateWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.DateWritable
 
DateWritable(DateWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.DateWritable
 
DateWritable(Date) - Constructor for class org.apache.hadoop.hive.serde2.io.DateWritable
 
DateWritable(int) - Constructor for class org.apache.hadoop.hive.serde2.io.DateWritable
 
daysToMillis(int) - Static method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
daysToMillis(int, boolean) - Static method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
daysToNanoseconds(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
db - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
db - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
db - Variable in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
DB_DERBY - Static variable in class org.apache.hive.beeline.HiveSchemaHelper
 
DB_MSSQL - Static variable in class org.apache.hive.beeline.HiveSchemaHelper
 
DB_MYSQL - Static variable in class org.apache.hive.beeline.HiveSchemaHelper
 
DB_ORACLE - Static variable in class org.apache.hive.beeline.HiveSchemaHelper
 
DB_POSTGRACE - Static variable in class org.apache.hive.beeline.HiveSchemaHelper
 
dbinfo(String) - Method in class org.apache.hive.beeline.Commands
 
dbLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DbLockManager - Class in org.apache.hadoop.hive.ql.lockmgr
An implementation of HiveLockManager for use with DbTxnManager.
dbname - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
dbName(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for db-name.
dbNameMapping - Variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
DbNotificationListener - Class in org.apache.hive.hcatalog.listener
An implementation of MetaStoreEventListener that stores events in the database.
DbNotificationListener(Configuration) - Constructor for class org.apache.hive.hcatalog.listener.DbNotificationListener
 
dbProduct - Variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
dbProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dbPropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DBTokenStore - Class in org.apache.hadoop.hive.thrift
 
DBTokenStore() - Constructor for class org.apache.hadoop.hive.thrift.DBTokenStore
 
DbTxnManager - Class in org.apache.hadoop.hive.ql.lockmgr
An implementation of HiveTxnManager that stores the transactions in the metastore database.
dbVars - Static variable in class org.apache.hadoop.hive.conf.HiveConf
dbVars are the parameters can be set per database.
ddl(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Execute an hcat ddl expression on the local box.
DDL_ID - Static variable in class org.apache.hive.hcatalog.templeton.Server
 
DDL_TIME - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
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
 
ddlStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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>, ShowConfDesc) - 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
 
Deadline - Class in org.apache.hadoop.hive.metastore
This class is used to monitor long running methods in a thread.
DeadlineException - Exception in org.apache.hadoop.hive.metastore
Thrown when a long running method timeout is checked.
DeadlineException(String) - Constructor for exception org.apache.hadoop.hive.metastore.DeadlineException
 
deadlockCnt - Variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Number of consecutive deadlocks we have seen
debugDisplayAllMaps(BaseWork) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer
 
debugDisplayBatch(VectorizedRowBatch, String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
debugDisplayOneRow(VectorizedRowBatch, int, String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
debugDumpMetrics() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
debugDumpTable() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Writes the debug dump of the table into logs.
debugLog() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.Hadoop20SFileStatus
 
debugLog() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.Hadoop23FileStatus
 
debugLog() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsFileStatus
 
debugStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Debug output.
decideExecMode(List<Task<? extends Serializable>>, Context, GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
decideExecMode(List<Task<? extends Serializable>>, Context, GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
 
decideExecMode(List<Task<? extends Serializable>>, Context, GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
decideExecMode(List<Task<? extends Serializable>>, Context, GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
Decimal - Class in org.apache.hadoop.hive.metastore.api
 
Decimal() - Constructor for class org.apache.hadoop.hive.metastore.api.Decimal
 
Decimal(ByteBuffer, short) - Constructor for class org.apache.hadoop.hive.metastore.api.Decimal
 
Decimal(Decimal) - Constructor for class org.apache.hadoop.hive.metastore.api.Decimal
Performs a deep copy on other.
DECIMAL - Static variable in class org.apache.hive.hcatalog.data.DataType
 
Decimal._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Decimal128 - Class in org.apache.hadoop.hive.common.type
This code was based on code from Microsoft's PolyBase.
Decimal128() - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Construct a zero.
Decimal128(Decimal128) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Copy constructor.
Decimal128(double, short) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Translates a double into a Decimal128 in the given scaling.
Decimal128(UnsignedInt128, short, boolean) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Translates a UnsignedInt128 unscaled value, an int scale, and sign flag into a Decimal128 .
Decimal128(long) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Translates a long into a Decimal128.
Decimal128(long, short) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Translates a long into a Decimal128 with the given scaling.
Decimal128(String, short) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Constructs from the given string.
Decimal128(char[], int, int, short) - Constructor for class org.apache.hadoop.hive.common.type.Decimal128
Constructs from the given string with given offset and length.
Decimal128FastBuffer - Class in org.apache.hive.common.util
A helper class for fast serialization of decimal128 in the BigDecimal byte[] representation
Decimal128FastBuffer() - Constructor for class org.apache.hive.common.util.Decimal128FastBuffer
 
DECIMAL_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
DECIMAL_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
DECIMAL_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
DECIMAL = 14;
decimalCharSet - Static variable in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
DecimalColAddDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColAddDecimalColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
DecimalColAddDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
DecimalColAddDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColAddDecimalScalar(int, HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalScalar
 
DecimalColAddDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalScalar
 
DecimalColDivideDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColDivideDecimalColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalColumn
 
DecimalColDivideDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalColumn
 
DecimalColDivideDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnDivideScalarDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColDivideDecimalScalar(int, HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalScalar
 
DecimalColDivideDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalScalar
 
DecimalColModuloDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColModuloDecimalColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalColumn
 
DecimalColModuloDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalColumn
 
DecimalColModuloDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnDivideScalarDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColModuloDecimalScalar(int, HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalScalar
 
DecimalColModuloDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalScalar
 
DecimalColMultiplyDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColMultiplyDecimalColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
DecimalColMultiplyDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
DecimalColMultiplyDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColMultiplyDecimalScalar(int, HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalScalar
 
DecimalColMultiplyDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalScalar
 
DecimalColSubtractDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColSubtractDecimalColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
DecimalColSubtractDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
DecimalColSubtractDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarDecimal.txt, which covers binary arithmetic expressions between a column and a scalar.
DecimalColSubtractDecimalScalar(int, HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalScalar
 
DecimalColSubtractDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalScalar
 
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.
DecimalColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
DecimalColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
DecimalColumnStatsData(long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
DecimalColumnStatsData(DecimalColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Performs a deep copy on other.
DecimalColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
decimalIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
decimalIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
indices of decimal primitive keys.
decimalIndicesIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
DecimalLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DecimalLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DecimalLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
DecimalLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DecimalLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
DecimalScalarAddDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a scalar and a column.
DecimalScalarAddDecimalColumn(HiveDecimal, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarAddDecimalColumn
 
DecimalScalarAddDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarAddDecimalColumn
 
DecimalScalarDivideDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarDivideColumnDecimal.txt, which covers binary arithmetic expressions between a scalar and a column.
DecimalScalarDivideDecimalColumn(HiveDecimal, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarDivideDecimalColumn
 
DecimalScalarDivideDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarDivideDecimalColumn
 
DecimalScalarModuloDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarDivideColumnDecimal.txt, which covers binary arithmetic expressions between a scalar and a column.
DecimalScalarModuloDecimalColumn(HiveDecimal, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarModuloDecimalColumn
 
DecimalScalarModuloDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarModuloDecimalColumn
 
DecimalScalarMultiplyDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a scalar and a column.
DecimalScalarMultiplyDecimalColumn(HiveDecimal, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarMultiplyDecimalColumn
 
DecimalScalarMultiplyDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarMultiplyDecimalColumn
 
DecimalScalarSubtractDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnDecimal.txt, which covers binary arithmetic expressions between a scalar and a column.
DecimalScalarSubtractDecimalColumn(HiveDecimal, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarSubtractDecimalColumn
 
DecimalScalarSubtractDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarSubtractDecimalColumn
 
DECIMALSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
decimalStats(DecimalColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
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
 
decimalToTimestamp(HiveDecimal) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
decimalTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
decimalTypeInfo - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDecimalResults
 
DecimalTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
 
DecimalTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
DecimalTypeInfo(int, int) - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
decimalTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
A DecimalTypeInfo instance that has max precision and max scale.
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
 
decimalWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
decimalWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
decimalWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
decodeArray(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Take an encode strings and decode it into an array of strings.
decodeBytes(String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
decodeDelegationTokenInformation(byte[]) - Static method in class org.apache.hadoop.security.token.delegation.HiveDelegationTokenSupport
 
decodeIfNeeded(byte[]) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyBinary
 
decodeWritable(Writable, String) - Static method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
decompose(Configuration, ExprNodeDesc) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
decomposePredicate(String, ExprNodeDesc) - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer
 
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
decomposePredicate(JobConf, HBaseSerDe, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler
Gives the storage handler a chance to decompose a predicate.
decompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.CompressionCodec
Decompress the in buffer to the out buffer.
decompress() - Method in interface org.apache.hadoop.hive.serde2.columnar.LazyDecompressionCallback
 
decompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.DirectDecompressorShim
 
decrement(SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
decrementConstructive() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
decrementDestructive() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Subtracts one from this value.
decrementDestructive() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Subtracts one from this value.
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
deepCopy(Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
deepCopy(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
deepCopy() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
deepCopy() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
deepCopy() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
deepCopy() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TRow
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
deepCopy() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
deepCopyFieldSchemas(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
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 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
Lexical state.
DEFAULT_COMPARISON_ATTRIBUTES - Static variable in class org.apache.hive.hcatalog.api.HCatTable
The default set of attributes that can be diffed between HCatTables.
DEFAULT_COMPAT_LEVEL - Static variable in class org.apache.hive.common.HiveCompat
 
DEFAULT_DATABASE - Static variable in class org.apache.hive.jdbc.Utils
Hive's default database name
DEFAULT_DATABASE_COMMENT - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
DEFAULT_DATABASE_NAME - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
DEFAULT_FETCH_MAX_ROWS - Static variable in class org.apache.hive.service.cli.operation.Operation
 
DEFAULT_FETCH_ORIENTATION - Static variable in class org.apache.hive.service.cli.operation.Operation
 
DEFAULT_FETCH_ORIENTATION_SET - Static variable in class org.apache.hive.service.cli.operation.Operation
 
DEFAULT_FILTER_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter
 
DEFAULT_FPP - Static variable in class org.apache.hive.common.util.BloomFilter
 
DEFAULT_HIVE_CATALOG - Static variable in class org.apache.hive.service.cli.operation.MetadataOperation
 
DEFAULT_INPUT_FORMAT_CLASS - Static variable in class org.apache.hive.hcatalog.api.HCatTable
 
DEFAULT_MESSAGE_FACTORY_IMPL - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
DEFAULT_OUTPUT_FORMAT_CLASS - Static variable in class org.apache.hive.hcatalog.api.HCatTable
 
DEFAULT_PORT - Static variable in class org.apache.hive.hcatalog.templeton.Main
 
DEFAULT_PORT - Static variable in class org.apache.hive.jdbc.Utils
If host is provided, without a port.
DEFAULT_PREFIX - Static variable in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
DEFAULT_PROJECT_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
 
DEFAULT_SERDE_CLASS - Static variable in class org.apache.hive.hcatalog.api.HCatTable
 
DEFAULT_SIZE - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
DEFAULT_STORAGE_TYPE - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
DEFAULT_VISIBILITY_LABEL - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
DefaultAccumuloRowIdFactory - Class in org.apache.hadoop.hive.accumulo.serde
Default implementation of the AccumuloRowIdFactory which uses the normal AccumuloRowSerializer methods to serialize the field for storage into Accumulo.
DefaultAccumuloRowIdFactory() - Constructor for class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
defaultBoolVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
DefaultBucketMatcher - Class in org.apache.hadoop.hive.ql.exec
 
DefaultBucketMatcher() - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
defaultEndGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
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
 
DefaultFileAccess - Class in org.apache.hadoop.fs
Implements the default file access logic for HadoopShims.checkFileAccess(), for Hadoop versions which do not implement FileSystem.access().
DefaultFileAccess() - Constructor for class org.apache.hadoop.fs.DefaultFileAccess
 
defaultFloatVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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.
DefaultHBaseKeyFactory - Class in org.apache.hadoop.hive.hbase
 
DefaultHBaseKeyFactory() - Constructor for class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
DefaultHBaseValueFactory - Class in org.apache.hadoop.hive.hbase.struct
Default implementation of the HBaseValueFactory
DefaultHBaseValueFactory(int) - Constructor for class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
DefaultHCatRecord - Class in org.apache.hive.hcatalog.data
 
DefaultHCatRecord() - Constructor for class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
DefaultHCatRecord(int) - Constructor for class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
DefaultHCatRecord(List<Object>) - Constructor for class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
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
 
defaultIntVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
defaultLongVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
defaultMapSeparator - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
DefaultMetaStoreFilterHookImpl - Class in org.apache.hadoop.hive.metastore
Default no-op implementation of the MetaStoreFilterHook that returns the result as is
DefaultMetaStoreFilterHookImpl(HiveConf) - Constructor for class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
defaultNullString - Static variable in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
defaultPrimarySeparator - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
These are defaults, but for now leaving them like this.
defaultRowSeparator - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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.
defaultSecondarySeparator - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
DefaultSeparator - Static variable in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
DefaultSeparators - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
defaultStartGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
DefaultStateProvider - Class in org.apache.hive.hcatalog.data.transfer.state
 
DefaultStateProvider() - Constructor for class org.apache.hive.hcatalog.data.transfer.state.DefaultStateProvider
 
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
 
defaultStrVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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.
DEFAUTL_DELIMITER - Static variable in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
 
Definition() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
DefinitionType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
DELEGATION_KEY_UPDATE_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_KEY_UPDATE_INTERVAL_KEY - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_GC_INTERVAL - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_MAX_LIFETIME_DEFAULT - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_MAX_LIFETIME_KEY - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_RENEW_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_RENEW_INTERVAL_KEY - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_CLS - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_ACL - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_CONNECT_STR - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_CONNECT_STR_ALTERNATE - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_CONNECT_TIMEOUTMILLIS - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_ZNODE - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DELEGATION_TOKEN_STORE_ZK_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
DelegationTokenCache<JobId,TokenObject> - Class in org.apache.hive.hcatalog.templeton.tool
 
DelegationTokenCache() - Constructor for class org.apache.hive.hcatalog.templeton.tool.DelegationTokenCache
 
DelegationTokenIdentifier - Class in org.apache.hadoop.hive.thrift
A delegation token identifier that is specific to Hive.
DelegationTokenIdentifier() - Constructor for class org.apache.hadoop.hive.thrift.DelegationTokenIdentifier
Create an empty delegation token identifier for reading into.
DelegationTokenIdentifier(Text, Text, Text) - Constructor for class org.apache.hadoop.hive.thrift.DelegationTokenIdentifier
Create a new delegation token identifier
DelegationTokenSecretManager - Class in org.apache.hadoop.hive.thrift
A Hive specific delegation token secret manager.
DelegationTokenSecretManager(long, long, long, long) - Constructor for class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
Create a secret manager
DelegationTokenSelector - Class in org.apache.hadoop.hive.thrift
A delegation token that is specialized for Hive
DelegationTokenSelector() - Constructor for class org.apache.hadoop.hive.thrift.DelegationTokenSelector
 
DelegationTokenStore - Interface in org.apache.hadoop.hive.thrift
Interface for pluggable token store that can be implemented with shared external storage for load balancing and high availability (for example using ZooKeeper).
DelegationTokenStore.TokenStoreException - Exception in org.apache.hadoop.hive.thrift
Exception for internal token store errors that typically cannot be handled by the caller.
DelegationTokenStore.TokenStoreException(Throwable) - Constructor for exception org.apache.hadoop.hive.thrift.DelegationTokenStore.TokenStoreException
 
DelegationTokenStore.TokenStoreException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.thrift.DelegationTokenStore.TokenStoreException
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
delete(long, Object) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
delete(long, Object) - 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(TempletonStorage.Type, String) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
delete() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
delete() - Method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
 
delete(TempletonStorage.Type, String) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
Delete a data grouping (all data for a jobid, all tracking data for a job, etc.).
delete(TempletonStorage.Type, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
delete_partition_column_statistics(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
delete_partition_column_statistics(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
delete_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
delete_partition_column_statistics(String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
delete_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
delete_resources(SessionState.ResourceType, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
delete_resources(SessionState.ResourceType) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
delete_table_column_statistics(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
delete_table_column_statistics(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
delete_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
delete_table_column_statistics(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
delete_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
deleteData - Variable in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
deleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
DeleteDelegator - Class in org.apache.hive.hcatalog.templeton
Delete a job
DeleteDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.DeleteDelegator
 
deleteDir(FileSystem, Path, boolean, boolean, Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
deleteDir(FileSystem, Path, boolean, boolean, Configuration) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFS
delete a directory
deleteDir(Path, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
deleteDir(Path, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
deleteJobId(String) - Method in class org.apache.hive.hcatalog.templeton.Server
Kill a job in the queue.
deleteKey(String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
deleteKey(String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
 
deleteKey(String) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
deleteOnExit(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
deletePartitionColumnStatistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Delete partition level column statistics given dbName, tableName, partName and colName
deletePartitionColumnStatistics(String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Delete partition level column statistics given dbName, tableName, partName and colName
deletePartitionColumnStatistics(String, String, String, List<String>, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
deletePartitionColumnStatistics(String, String, String, List<String>, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Deletes column statistics if present associated with a given db, table, partition and col.
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
 
deleteRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
deletesAreDetected(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
deleteStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
deleteTableColumnStatistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Delete table level column statistics given dbName, tableName and colName
deleteTableColumnStatistics(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Delete table level column statistics given dbName, tableName and colName
deleteTableColumnStatistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
deleteTableColumnStatistics(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Deletes column statistics if present associated with a given db, table and col.
deleteTableColumnStatistics(String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
deleteTableColumnStatistics(String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
Delete table level column statistics given dbName, tableName and colName
deleteWHDirectory(Path, Configuration, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
deleting() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
deleting() - Method in class org.apache.hadoop.hive.ql.parse.UpdateDeleteSemanticAnalyzer
 
DELIMITED_CANDIDATE_THRESHOLD - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
DelimitedInputWriter - Class in org.apache.hive.hcatalog.streaming
Streaming Writer handles delimited input (eg.
DelimitedInputWriter(String[], String, HiveEndPoint) - Constructor for class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
Constructor.
DelimitedInputWriter(String[], String, HiveEndPoint, HiveConf) - Constructor for class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
Constructor.
DelimitedInputWriter(String[], String, HiveEndPoint, HiveConf, char) - Constructor for class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
Constructor.
DelimitedJSONSerDe - Class in org.apache.hadoop.hive.serde2
DelimitedJSONSerDe.
DelimitedJSONSerDe() - Constructor for class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
 
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
 
DELTA_SIDE_FILE_SUFFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
deltaFileFilter - 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
 
DependencyResolver - Class in org.apache.hadoop.hive.ql.session
 
DependencyResolver() - Constructor for class org.apache.hadoop.hive.ql.session.DependencyResolver
 
dependencyTask - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
dependencyTask - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
deploy(Service, HiveConf) - Static method in class org.apache.hive.service.ServiceOperations
Initialize then start a service.
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
 
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.
deriveMinArgumentCast(ExprNodeDesc, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
deriveResultApproxTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
Default implementation for getting the approximate type info for the operator result.
deriveResultApproxTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
deriveResultDecimalTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
Derive the object inspector instance for the decimal result of the operator.
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
A balanced way to determine the precision/scale of decimal division result.
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
deriveResultDecimalTypeInfo(int, int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
deriveResultExactTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
Default implementation for getting the exact type info for the operator result.
deriveResultExactTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
deriveResultExactTypeInfoAnsiSql() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
deriveResultExactTypeInfoBackwardsCompat() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
deriveRowType() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
deriveRowType(RelDataTypeFactory, RelDataType, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
deriveRowType() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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.
desc - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTableLoader
 
descColumn(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Describe a single column in an hcat table.
descDatabase(String, String, boolean) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of the database.
descDatabase(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Describe a database
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
 
descExtendedTable(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json "show table extended like" with extra info from "desc exteded" This will return table with exact name match.
descFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
descFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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
 
descOneColumn(String, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of one column.
descOnePartition(String, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of one partition.
descOneTableProperty(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Describe a single property on an hcat table.
descPartition(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Describe a single partition in an hcat table.
describe(String) - Method in class org.apache.hive.beeline.Commands
 
describeTable(DataOutputStream, String, String, Table, Partition, List<FieldSchema>, boolean, boolean, boolean, boolean, List<ColumnStatisticsObj>) - 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, List<ColumnStatisticsObj>) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Describe table.
Description - Annotation Type in org.apache.hadoop.hive.ql.exec
Description.
descStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
descTable(String, String, String, boolean) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of the table.
descTable(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Describe an hcat table.
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
 
descTableProperty(String, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Describe one table property.
deserialize(Writable) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
deserialize(S3LogStruct, String) - Static method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
Deserialize a row from the HBase Result writable to a LazyObject
deserialize(InputStream) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
deserialize(byte[], Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.spark.KryoSerializer
 
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(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractDeserializer
Deserialize an object out of a Writable blob.
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Deserialize an object out of a Writable blob.
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
deserialize(Writable) - Method in interface org.apache.hadoop.hive.serde2.Deserializer
Deprecated.
Deserialize an object out of a Writable blob.
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
deserialize(TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
NOTE: Set is not supported by Hive yet.
deserialize(TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
deserialize(Object, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Deserialize a table record to a lazybinary struct.
deserialize(ColumnSet, String, String, String, int) - Static method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
Split the row into columns.
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
deserialize(String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
deserialize(Writable) - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
The purpose of a deserialize method is to turn a data blob which is a writable representation of the data into an object that can then be parsed using the appropriate ObjectInspector.
deserialize(Writable) - Method in class org.apache.hive.hcatalog.data.JsonSerDe
Takes JSON string in Text form, and has to return an object representation above it that's readable by the corresponding object inspector.
DESERIALIZE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
deserializeByReference(VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
deserializeByValue(VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
deserializeCache - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
deserializeCommand(String) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Command implements Writable, but that's not terribly easy to use compared to String, even if it plugs in easily into the rest of Hadoop.
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.
deserializeJobConf(byte[]) - Static method in class org.apache.hadoop.hive.ql.exec.spark.KryoSerializer
 
deserializeLongKey(BinarySortableDeserializeRead, VectorMapJoinDesc.HashTableKeyType) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashUtil
 
deserializeObject(String, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
deserializePartition(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Deserializer for an HCatPartition.
deserializePartition(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
deserializePartitions(List<String>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Deserializer for a list of HCatPartition strings.
deserializePartitions(List<String>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
deserializePartitionSpec(List<String>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Deserializer for HCatPartitionSpec.
deserializePartitionSpec(List<String>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
deserializePlan(InputStream, Class<T>, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Deserializes the plan.
Deserializer - Interface in org.apache.hadoop.hive.serde2
Deprecated.
DeserializeRead - Interface in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadBinaryResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadBinaryResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadBinaryResults
 
DeserializeRead.ReadBytesResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadBytesResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadBytesResults
 
DeserializeRead.ReadDateResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadDateResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDateResults
 
DeserializeRead.ReadDecimalResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadDecimalResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDecimalResults
 
DeserializeRead.ReadHiveCharResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadHiveCharResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
DeserializeRead.ReadHiveVarcharResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadHiveVarcharResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
DeserializeRead.ReadIntervalDayTimeResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadIntervalDayTimeResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalDayTimeResults
 
DeserializeRead.ReadIntervalYearMonthResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadIntervalYearMonthResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalYearMonthResults
 
DeserializeRead.ReadStringResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadStringResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadStringResults
 
DeserializeRead.ReadTimestampResults - Class in org.apache.hadoop.hive.serde2.fast
 
DeserializeRead.ReadTimestampResults() - Constructor for class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadTimestampResults
 
deserializeTable(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Deserializer for HCatTable.
deserializeTable(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
deserializeText(InputByteBuffer, boolean, Text) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
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
 
destination() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
destruct() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
detachSession() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
detail - Variable in class org.apache.hive.hcatalog.templeton.JobItemBean
 
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.
determineCommonInfo(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
determineDatabaseProduct(Connection) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Determine the database product type
determineSchemaOrReturnErrorSchema(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
Attempt to determine the schema via the usual means, but do not throw an exception if we fail.
determineSchemaOrThrowException(Configuration, Properties) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Determine the schema to that's been provided for Avro serde work.
dfa10 - Variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
dfa111 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dfa12 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dfa13 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa14 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa14 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa14 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa15 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa16 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa16 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa16 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa17 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa19 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa19 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa199 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dfa2 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa20 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa21 - Variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
dfa21 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa23 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa25 - Variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
dfa26 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa27 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa28 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa28 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa29 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa31 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa31 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa32 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa33 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa36 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa37 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa38 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa39 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
dfa39 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa40 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa43 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa44 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa5 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
dfa6 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
dfa7 - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
DICTIONARY_COUNT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
DICTIONARY_COUNT = 4;
DICTIONARY_DATA_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
DICTIONARY_DATA = 3;
DICTIONARY_V2_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
DICTIONARY_V2 = 3;
DICTIONARY_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
DICTIONARY = 1;
DICTIONARYSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
diff(HCatTable, EnumSet<HCatTable.TableAttribute>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Method to compare the attributes of 2 HCatTable instances.
diff(HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatTable
Method to compare the attributes of 2 HCatTable instances.
difference(UnsignedInt128, UnsignedInt128, UnsignedInt128) - Static method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Calculates absolute difference (remember that this is unsigned) of left and right operator.
differenceScaleTen(UnsignedInt128, UnsignedInt128, UnsignedInt128, short) - Static method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Calculates absolute difference of left and right operator after ten-based scaling on right.
DigestPrintStream - Class in org.apache.hadoop.hive.common.io
 
DigestPrintStream(OutputStream, String) - Constructor for class org.apache.hadoop.hive.common.io.DigestPrintStream
 
Digit - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
Digit - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
Digit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Digit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Digit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
Digit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Digit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
DIGIT - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
digit(int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Returns the digit represented by character b.
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
 
dimensionId - Variable in class org.apache.hadoop.hive.ql.metadata.Dimension
 
dimensionType - Variable in class org.apache.hadoop.hive.ql.metadata.Dimension
 
DIRECT_V2_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
DIRECT_V2 = 2;
DIRECT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
DIRECT = 0;
directDecompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.DirectDecompressionCodec
 
DirectDecompressionCodec - Interface in org.apache.hadoop.hive.ql.io.orc
 
directSpillPartitionId() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.ReusableGetAdaptorDirectAccess
 
disable_tracing() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Disable tracing.
disableJoinMerge - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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
 
discardCleanupFor(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry
Method to discard the committer call-backs for a specified TaskAttemptID.
discarded() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
disconnect(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
disconnect removes an edge between a and b.
disconnect(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
disconnect removes an edge between a and b.
diskBytesSpilled - Variable in class org.apache.hive.spark.client.metrics.Metrics
The number of on-disk bytes spilled by tasks.
DiskRange - Class in org.apache.hadoop.hive.common
The sections of a file.
DiskRange(long, long) - Constructor for class org.apache.hadoop.hive.common.DiskRange
 
DiskRangeList - Class in org.apache.hadoop.hive.common
Java linked list iterator interface is convoluted, and moreover concurrent modifications of the same list by multiple iterators are impossible.
DiskRangeList(long, long) - Constructor for class org.apache.hadoop.hive.common.DiskRangeList
 
DiskRangeList.DiskRangeListCreateHelper - Class in org.apache.hadoop.hive.common
 
DiskRangeList.DiskRangeListCreateHelper() - Constructor for class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListCreateHelper
 
DiskRangeList.DiskRangeListMutateHelper - Class in org.apache.hadoop.hive.common
List in-place mutation helper - a bogus first element that is inserted before list head, and thus remains constant even if head is replaced with some new range via in-place list mutation.
DiskRangeList.DiskRangeListMutateHelper(DiskRangeList) - Constructor for class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListMutateHelper
 
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>, 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
 
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.NullScanTaskDispatcher
 
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SparkCrossProductCheck
 
dispatchAndReturn(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
Returns dispatch result
dispatcher - Variable in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
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.
displayBatchColumns(VectorizedRowBatch, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
displayBytes(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashUtil
 
displayBytes(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
dispose() - Method in class org.apache.hive.service.auth.PlainSaslServer
 
distinctColIndices - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
DistinctElementsClassPath - Class in org.apache.hadoop.hive.ant
This object represents a path as used by CLASSPATH or PATH environment variable.
DistinctElementsClassPath(Project, String) - Constructor for class org.apache.hadoop.hive.ant.DistinctElementsClassPath
Invoked by IntrospectionHelper for setXXX(Path p) attribute setters.
DistinctElementsClassPath(Project) - Constructor for class org.apache.hadoop.hive.ant.DistinctElementsClassPath
Construct an empty Path.
distinctExprsExists(QB) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
distributeByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
distributeByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
distribution(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistribution
 
distribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistribution
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
divide(Decimal128, Decimal128, Decimal128, short) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Performs division and puts the result into the given object.
divide(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
divide(SignedInt128, SignedInt128, SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
Performs division and puts the quotient into the given object.
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
divideBy(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
divideChecked(int, HiveDecimal, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
divideChecked(int, HiveDecimalWritable, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
divideChecked(int, HiveDecimalWritable, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
divideChecked(int, HiveDecimal, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
divideConstructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
divideConstructive(UnsignedInt128, UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
divideDestructive(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Divide the target object by right, and scale the result to newScale.
divideDestructive(int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Divides this value with the given value.
divideDestructive(SignedInt128, SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Performs division and puts the quotient into this object.
divideDestructive(UnsignedInt128, UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Divides this value with the given value.
divideDestructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Divides this value with the given value.
divideDestructive(long) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Divides this value with the given value.
divideDestructiveNativeDecimal128(Decimal128, short, Decimal128) - Method in class org.apache.hadoop.hive.common.type.Decimal128
As of 1/20/2014 this has a known bug in division.
divideMultiPrecision(int[], int[], int[]) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
Multi-precision divide.
divideScaleUpTenDestructive(UnsignedInt128, short, UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Scale up this object for 10**tenScale and then divides this value with the given value.
divideUnsignedLong(long, long) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
If we can assume JDK 1.8, this should use java.lang.Long.divideUnsigned(), which will be replaced with intrinsics in JVM.
DO_AS_PARAM - Static variable in class org.apache.hive.hcatalog.templeton.Server
 
DO_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
DO_NOT_UPDATE_STATS - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
doAppend(LoggingEvent) - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
doAppend(LoggingEvent) - Method in class org.apache.hive.service.cli.operation.LogDivertAppender
 
doAuthorization(BaseSemanticAnalyzer, String) - Static method in class org.apache.hadoop.hive.ql.Driver
Do authorization using post semantic analysis information in the semantic analyzer The original command is also passed so that authorization interface can provide more useful information in logs.
doCallback(String, String) - Static method in class org.apache.hive.hcatalog.templeton.CompleteDelegator
Call the callback url with the jobid to let them know it's finished.
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
 
doDeserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
doDeserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
Not implemented.
doDeserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Deserialize a row from the Writable to a LazyObject.
doesAlterTableTypeSupportPartialPartitionSpec(AlterTableDesc.AlterTableTypes) - Static method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
doesMaxRowSizeIncludeBlobs() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
doesPartitionExist(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
doesPartitionExist(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
doesPrimitiveMatchTypeParams(HiveBaseChar, BaseCharTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharUtils
 
doesWritableMatchTypeParams(HiveBaseCharWritable, BaseCharTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharUtils
 
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAcos
Take Arc Cosine of a in radians.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAsin
Take Arc Sine of a in radians.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAtan
 
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFCos
Take Cosine of a.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDegrees
 
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFExp
Raise e (the base of natural logarithm) to the power of a.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLn
Returns the natural logarithm of "a".
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the natural logarithm of "a".
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog10
Returns the logarithm of "a" with base 10.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog2
Returns the logarithm of "a" with base 2.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMath
For subclass to implement.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRadians
 
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSin
Take Sine of a.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSqrt
Return NULL for negative inputs; otherwise, return the square root.
doEvaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFTan
Take Tangent of a
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
doGetField(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
doGetField(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampString
 
doGetField(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearString
 
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
doInit() - Method in class org.apache.hive.beeline.HiveSchemaTool
Initialize the metastore schema to current version
doInit(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
Initialize the metastore schema
doIterate(GenericUDAFAverage.AverageAggregationBuffer<TYPE>, PrimitiveObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
doIterate(GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal>, PrimitiveObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
doIterate(GenericUDAFAverage.AverageAggregationBuffer<Double>, PrimitiveObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
doLookup(byte[], int, int, BytesBytesMultiHashMap.Result, VectorMapJoinHashTableResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
doMerge(GenericUDAFAverage.AverageAggregationBuffer<TYPE>, Long, ObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
doMerge(GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal>, Long, ObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
doMerge(GenericUDAFAverage.AverageAggregationBuffer<Double>, Long, ObjectInspector, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
done() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
done - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
done() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
Done() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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, SemanticAnalyzer.PlannerContext) - 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
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hive.service.cli.thrift.ThriftHttpServlet
 
doPrimitiveCategoriesMatch(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
returns true if both TypeInfos are of primitive type, and the primitive category matches.
doReset(GenericUDAFAverage.AverageAggregationBuffer<TYPE>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
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
 
doSerialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
doSerialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Serialize a row of data.
doSpillOnCreation(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
Check if a partition should be spilled directly on creation
DosToUnix - Class in org.apache.hadoop.hive.ql.util
 
DosToUnix() - Constructor for class org.apache.hadoop.hive.ql.util.DosToUnix
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
doTerminate(GenericUDAFAverage.AverageAggregationBuffer<TYPE>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
doTerminate(GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
doTerminate(GenericUDAFAverage.AverageAggregationBuffer<Double>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
doTerminatePartial(GenericUDAFAverage.AverageAggregationBuffer<TYPE>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
doTerminatePartial(GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
doTerminatePartial(GenericUDAFAverage.AverageAggregationBuffer<Double>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
DOUBLE - Static variable in class org.apache.hive.hcatalog.data.DataType
 
DOUBLE_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
DOUBLE_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
DOUBLE = 6;
DoubleColAddDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColAddDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
DoubleColAddDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
DoubleColAddDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColAddDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
DoubleColAddDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
DoubleColAddLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColAddLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
DoubleColAddLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
DoubleColAddLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColAddLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
DoubleColAddLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
DoubleColDivideDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColDivideDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
DoubleColDivideDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
DoubleColDivideDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColDivideDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
DoubleColDivideDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
DoubleColDivideLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColDivideLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
DoubleColDivideLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
DoubleColDivideLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColDivideLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
DoubleColDivideLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
DoubleColEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
DoubleColEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
DoubleColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
DoubleColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
DoubleColEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
DoubleColEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
DoubleColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
DoubleColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
DoubleColGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColGreaterDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
DoubleColGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
DoubleColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColGreaterDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
DoubleColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
DoubleColGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColGreaterEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
DoubleColGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
DoubleColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColGreaterEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
DoubleColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
DoubleColGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColGreaterEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
DoubleColGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
DoubleColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColGreaterEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
DoubleColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
DoubleColGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColGreaterLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
DoubleColGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
DoubleColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColGreaterLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
DoubleColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
DoubleColLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColLessDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
DoubleColLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
DoubleColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColLessDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
DoubleColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
DoubleColLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColLessEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
DoubleColLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
DoubleColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColLessEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
DoubleColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
DoubleColLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColLessEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
DoubleColLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
DoubleColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColLessEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
DoubleColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
DoubleColLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColLessLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
DoubleColLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
DoubleColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColLessLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
DoubleColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
DoubleColModuloDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColModuloDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
DoubleColModuloDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
DoubleColModuloDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColModuloDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
DoubleColModuloDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
DoubleColModuloLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColModuloLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
DoubleColModuloLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
DoubleColModuloLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColModuloLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
DoubleColModuloLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
DoubleColMultiplyDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColMultiplyDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
DoubleColMultiplyDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
DoubleColMultiplyDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColMultiplyDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
DoubleColMultiplyDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
DoubleColMultiplyLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColMultiplyLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
DoubleColMultiplyLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
DoubleColMultiplyLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColMultiplyLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
DoubleColMultiplyLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
DoubleColNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColNotEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
DoubleColNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
DoubleColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColNotEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
DoubleColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
DoubleColNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColNotEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
DoubleColNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
DoubleColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleColNotEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
DoubleColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
DoubleColSubtractDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColSubtractDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
DoubleColSubtractDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
DoubleColSubtractDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColSubtractDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
DoubleColSubtractDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
DoubleColSubtractLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
DoubleColSubtractLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
DoubleColSubtractLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
DoubleColSubtractLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
DoubleColSubtractLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
DoubleColSubtractLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
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.
DoubleColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
DoubleColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
DoubleColumnStatsData(long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
DoubleColumnStatsData(DoubleColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Performs a deep copy on other.
DoubleColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
DoubleColUnaryMinus - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnUnaryMinus.txt, which covers unary negation operator.
DoubleColUnaryMinus(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
DoubleColUnaryMinus() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
DoubleCompare - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Set of comparison operations over a double constant.
DoubleCompare() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
doubleIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
doubleIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
indices of DOUBLE primitive keys.
doubleIndicesIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
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
 
DoubleObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A DoubleObjectInspector inspects an Object representing a Double.
DoubleScalarAddDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarAddDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
DoubleScalarAddDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
DoubleScalarAddLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarAddLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
DoubleScalarAddLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
DoubleScalarDivideDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarDivideDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
DoubleScalarDivideDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
DoubleScalarDivideLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarDivideLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
DoubleScalarDivideLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
DoubleScalarEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarEqualDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
DoubleScalarEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
DoubleScalarEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarEqualLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
DoubleScalarEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
DoubleScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarEqualTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualTimestampColumn
 
DoubleScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualTimestampColumn
 
DoubleScalarGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarGreaterDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
DoubleScalarGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
DoubleScalarGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarGreaterEqualDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
DoubleScalarGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
DoubleScalarGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarGreaterEqualLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
DoubleScalarGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
DoubleScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarGreaterEqualTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualTimestampColumn
 
DoubleScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualTimestampColumn
 
DoubleScalarGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarGreaterLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
DoubleScalarGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
DoubleScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarGreaterTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterTimestampColumn
 
DoubleScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterTimestampColumn
 
DoubleScalarLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarLessDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
DoubleScalarLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
DoubleScalarLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarLessEqualDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
DoubleScalarLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
DoubleScalarLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarLessEqualLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
DoubleScalarLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
DoubleScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarLessEqualTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualTimestampColumn
 
DoubleScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualTimestampColumn
 
DoubleScalarLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarLessLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
DoubleScalarLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
DoubleScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarLessTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessTimestampColumn
 
DoubleScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessTimestampColumn
 
DoubleScalarModuloDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarModuloDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
DoubleScalarModuloDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
DoubleScalarModuloLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarModuloLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
DoubleScalarModuloLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
DoubleScalarMultiplyDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarMultiplyDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
DoubleScalarMultiplyDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
DoubleScalarMultiplyLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarMultiplyLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
DoubleScalarMultiplyLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
DoubleScalarNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarNotEqualDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
DoubleScalarNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
DoubleScalarNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
DoubleScalarNotEqualLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
DoubleScalarNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
DoubleScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
DoubleScalarNotEqualTimestampColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualTimestampColumn
 
DoubleScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualTimestampColumn
 
DoubleScalarSubtractDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarSubtractDoubleColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
DoubleScalarSubtractDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
DoubleScalarSubtractLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
DoubleScalarSubtractLongColumn(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
DoubleScalarSubtractLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
DOUBLESTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
doubleStats(DoubleColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
doubleToNanoseconds(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
doubleToTimestamp(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
doubleToTimestamp(double) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
doubleTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
doubleTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
doubleVal(TDoubleColumn) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
doubleVal(TDoubleValue) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
doubleValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Converts this Decimal128 to a double.
doubleValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
doubleValue() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
doubleValue(double) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
doubleWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
doubleWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
DoubleWritable - Class in org.apache.hadoop.hive.serde2.io
Writable for Double values.
DoubleWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
DoubleWritable(double) - Constructor for class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
doUpgrade() - Method in class org.apache.hive.beeline.HiveSchemaTool
Perform metastore schema upgrade.
doUpgrade(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
Perform metastore schema upgrade
downloadDependencies(URI) - Method in class org.apache.hadoop.hive.ql.session.DependencyResolver
 
dpColNames - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpCtx - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
dpCtx - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpPath - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
dpStartCol - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpVals - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpWritables - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
driverContext - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
DriverInfo - Class in org.apache.hive.beeline
 
DriverInfo(String) - Constructor for class org.apache.hive.beeline.DriverInfo
 
DriverInfo(Properties) - Constructor for class org.apache.hive.beeline.DriverInfo
 
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
 
drop_database(String, boolean, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_database(String, boolean, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_database(String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_database(String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_database(String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_function(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_function_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_function(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_function_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_function(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_function(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_function(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_index_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_index_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_index_by_name(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition(String, String, List<String>, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition_by_name(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partitions_req(DropPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partitions_req_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partitions_req(DropPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partitions_req_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partitions_req(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partitions_req(DropPartitionsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partitions_req(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_role(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_role(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_role(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
drop_role(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
drop_table(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_table(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_table(String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
drop_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_type(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_type(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
dropall(String) - Method in class org.apache.hive.beeline.Commands
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropDatabase(String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropDatabase(String, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
dropDatabase(String, boolean, HCatClient.DropDBMode) - Method in class org.apache.hive.hcatalog.api.HCatClient
Drops a database.
dropDatabase(String, boolean, HCatClient.DropDBMode) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
dropDatabase(String, String, boolean, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Drop the given database
dropDatabase(String, boolean, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Drop a database
DropDatabaseCommand - Class in org.apache.hive.hcatalog.api.repl.commands
 
DropDatabaseCommand(String, long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
DropDatabaseCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
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
 
DropDatabaseEvent - Class in org.apache.hadoop.hive.metastore.events
 
DropDatabaseEvent(Database, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.DropDatabaseEvent
 
DropDatabaseMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a Database is dropped from HCatalog.
DropDatabaseMessage() - Constructor for class org.apache.hive.hcatalog.messaging.DropDatabaseMessage
 
DropDatabaseReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
DropDatabaseReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.DropDatabaseReplicationTask
 
dropDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropFunction(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropFunction(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropFunction(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropFunction(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Drop a function definition.
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
 
dropFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropIndex(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropIndex(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropIndex(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropIndex(String, String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DropIndexDesc - Class in org.apache.hadoop.hive.ql.plan
 
DropIndexDesc(String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
DropIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
DropIndexEvent(Index, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.DropIndexEvent
 
dropIndexStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
dropMacroStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, List<String>, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, List<String>, PartitionDropOptions) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, List<String>, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartition(String, String, List<String>, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropPartition(String, String, List<String>, PartitionDropOptions) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Method to dropPartitions() with the option to purge the partition data directly, rather than to move data to trash.
dropPartition(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
dropPartition(String, String, List<String>, PartitionDropOptions) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartition(String, String, String, String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Drop a partition.
dropPartition(String, String, String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Drop a partition in an hcat table.
dropPartitionAllColumnGrantsNoTxn(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropPartitionByName(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartitionByName(String, String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
DropPartitionCommand - Class in org.apache.hive.hcatalog.api.repl.commands
 
DropPartitionCommand(String, String, Map<String, String>, boolean, long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
DropPartitionCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
DropPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
DropPartitionEvent(Table, Partition, boolean, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.DropPartitionEvent
 
DropPartitionMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a partition is dropped in HCatalog.
DropPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.DropPartitionMessage
 
dropPartitionOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropPartitionOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DropPartitionReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
DropPartitionReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.DropPartitionReplicationTask
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, PartitionDropOptions) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, boolean, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, boolean, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropPartitions(String, String, List<ObjectPair<Integer, byte[]>>, PartitionDropOptions) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Generalization of dropPartitions(),
dropPartitions(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropPartitions(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
dropPartitions(String, List<DropTableDesc.PartSpec>, PartitionDropOptions) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartitions(String, String, List<DropTableDesc.PartSpec>, PartitionDropOptions) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartitions(String, String, Map<String, String>, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClient
Drops partition(s) that match the specified (and possibly partial) partition specification.
dropPartitions(String, String, Map<String, String>, boolean, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClient
Drops partition(s) that match the specified (and possibly partial) partition specification.
dropPartitions(String, String, Map<String, String>, boolean, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
dropPartitions(String, String, Map<String, String>, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
DropPartitionsExpr - Class in org.apache.hadoop.hive.metastore.api
 
DropPartitionsExpr() - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
DropPartitionsExpr(ByteBuffer) - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
DropPartitionsExpr(DropPartitionsExpr) - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
Performs a deep copy on other.
DropPartitionsExpr._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
dropPartitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropPartitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
DropPartitionsRequest - Class in org.apache.hadoop.hive.metastore.api
 
DropPartitionsRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
DropPartitionsRequest(String, String, RequestPartsSpec) - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
DropPartitionsRequest(DropPartitionsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Performs a deep copy on other.
DropPartitionsRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DropPartitionsResult - Class in org.apache.hadoop.hive.metastore.api
 
DropPartitionsResult() - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
DropPartitionsResult(DropPartitionsResult) - Constructor for class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
Performs a deep copy on other.
DropPartitionsResult._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
dropPartitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropPartitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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.HiveV1Authorizer
 
dropRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
dropRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
dropRoleStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Drop the table.
dropTable(String, String, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Drop the table and choose whether to save the data in the trash.
dropTable(String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated.
dropTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, String, boolean, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Drop the table and choose whether to: delete the underlying table data; throw if the table doesn't exist; save the data in the trash.
dropTable(String, String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Drop the table.
dropTable(String, String, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropTable(String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated.
As of release 0.6.0 replaced by IMetaStoreClient.dropTable(String, String, boolean, boolean). This method will be removed in release 0.7.0.
dropTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropTable(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropTable(String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
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.
dropTable(String, String, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops the table.
dropTable(String, String, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClient
Drop table.
dropTable(String, String, boolean) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
dropTable(String, String, String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Drop a table.
dropTable(String, String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Drop an hcat table.
DropTableCommand - Class in org.apache.hive.hcatalog.api.repl.commands
 
DropTableCommand(String, String, boolean, long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
DropTableCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
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, boolean, ReplicationSpec) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc(String, Map<Integer, List<ExprNodeGenericFuncDesc>>, boolean, boolean, boolean, ReplicationSpec) - 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
 
DropTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
DropTableEvent(Table, boolean, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.DropTableEvent
 
DropTableMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when a Table is dropped in HCatalog.
DropTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.DropTableMessage
 
DropTableReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
DropTableReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.DropTableReplicationTask
 
dropTableStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropType(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropType(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropType(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropViewStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dstStagingDirProvider - Variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
dt - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToString
 
dt1Converter - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dt2Converter - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dtArg1Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dtArg2Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dtArgIdx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
dtConverter - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
dtm - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
dtm - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
dummy - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
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
 
DummyHiveAuthorizationValidator - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
A no-op HiveAuthorizationValidator for use from hive cli.
DummyHiveAuthorizationValidator() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.DummyHiveAuthorizationValidator
 
dummyObj - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
dummyObjVectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
 
dump(String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
dumpAndClearMetaCallTiming(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dumpHeap(String, boolean) - Static method in class org.apache.hadoop.hive.ql.debug.Utils
Dumps process heap.
dumpHeapToTmp(String...) - Static method in class org.apache.hadoop.hive.ql.debug.Utils
Dumps process heap to a file in temp directoty.
dumpHex() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Return the bytes in hex format.
dumpMetrics() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
dumpMetrics() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
dumpMetrics() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
dumpMetrics() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
dumpMetrics() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
dumpPropMap(String, Properties) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
dumpPropMap(String, Map<String, String>) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
dumpStats() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
duplicate() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
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
 
DynamicPartitionPruner - Class in org.apache.hadoop.hive.ql.exec.tez
DynamicPartitionPruner takes a list of assigned partitions at runtime (split generation) and prunes them using events generated during execution of the dag.
DynamicPartitionPruner(InputInitializerContext, MapWork, JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
DynamicPartitionPruningOptimization - Class in org.apache.hadoop.hive.ql.optimizer
This optimization looks for expressions of the kind "x IN (RS[n])".
DynamicPartitionPruningOptimization() - Constructor for class org.apache.hadoop.hive.ql.optimizer.DynamicPartitionPruningOptimization
 
DynamicPartitionPruningOptimization.DynamicPartitionPrunerProc - Class in org.apache.hadoop.hive.ql.optimizer
 
DynamicPartitionPruningOptimization.DynamicPartitionPrunerProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.DynamicPartitionPruningOptimization.DynamicPartitionPrunerProc
 
DynamicPruningEventDesc - Class in org.apache.hadoop.hive.ql.plan
 
DynamicPruningEventDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
DynamicSerDe - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDe.
DynamicSerDe() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
DynamicSerDeAsync - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeAsync(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeAsync
 
DynamicSerDeAsync(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeAsync
 
DynamicSerDeCommaOrSemicolon - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeCommaOrSemicolon(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeCommaOrSemicolon
 
DynamicSerDeCommaOrSemicolon(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeCommaOrSemicolon
 
DynamicSerDeConst - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConst(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConst
 
DynamicSerDeConst(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConst
 
DynamicSerDeConstList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstList
 
DynamicSerDeConstList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstList
 
DynamicSerDeConstListContents - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstListContents(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstListContents
 
DynamicSerDeConstListContents(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstListContents
 
DynamicSerDeConstMap - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstMap(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMap
 
DynamicSerDeConstMap(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMap
 
DynamicSerDeConstMapContents - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstMapContents(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMapContents
 
DynamicSerDeConstMapContents(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMapContents
 
DynamicSerDeConstValue - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstValue(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstValue
 
DynamicSerDeConstValue(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstValue
 
DynamicSerDeDefinition - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeDefinition(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinition
 
DynamicSerDeDefinition(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinition
 
DynamicSerDeDefinitionType - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeDefinitionType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinitionType
 
DynamicSerDeDefinitionType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinitionType
 
DynamicSerDeEnum - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnum(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnum
 
DynamicSerDeEnum(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnum
 
DynamicSerDeEnumDef - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnumDef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDef
 
DynamicSerDeEnumDef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDef
 
DynamicSerDeEnumDefList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnumDefList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDefList
 
DynamicSerDeEnumDefList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDefList
 
DynamicSerDeExtends - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeExtends(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeExtends
 
DynamicSerDeExtends(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeExtends
 
DynamicSerDeField - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeField.
DynamicSerDeField(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
DynamicSerDeField(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
DynamicSerDeFieldList - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldList.
DynamicSerDeFieldList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
DynamicSerDeFieldList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
DynamicSerDeFieldRequiredness - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldRequiredness.
DynamicSerDeFieldRequiredness(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
 
DynamicSerDeFieldRequiredness(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
 
DynamicSerDeFieldRequiredness.RequirednessTypes - Enum in org.apache.hadoop.hive.serde2.dynamic_type
RequirednessTypes.
DynamicSerDeFieldType - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldType.
DynamicSerDeFieldType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
DynamicSerDeFieldType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
DynamicSerDeFieldValue - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFieldValue(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldValue
 
DynamicSerDeFieldValue(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldValue
 
DynamicSerDeFlagArgs - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFlagArgs(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFlagArgs
 
DynamicSerDeFlagArgs(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFlagArgs
 
DynamicSerDeFunction - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFunction.
DynamicSerDeFunction(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
DynamicSerDeFunction(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
DynamicSerDeFunctionType - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFunctionType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunctionType
 
DynamicSerDeFunctionType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunctionType
 
DynamicSerDeHeader - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeHeader(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeader
 
DynamicSerDeHeader(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeader
 
DynamicSerDeHeaderList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeHeaderList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeaderList
 
DynamicSerDeHeaderList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeaderList
 
DynamicSerDeInclude - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeInclude(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeInclude
 
DynamicSerDeInclude(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeInclude
 
DynamicSerDeNamespace - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeNamespace(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeNamespace
 
DynamicSerDeNamespace(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeNamespace
 
DynamicSerDeSenum - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenum(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenum
 
DynamicSerDeSenum(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenum
 
DynamicSerDeSenumDef - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenumDef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDef
 
DynamicSerDeSenumDef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDef
 
DynamicSerDeSenumDefList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenumDefList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDefList
 
DynamicSerDeSenumDefList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDefList
 
DynamicSerDeService - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeService(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeService
 
DynamicSerDeService(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeService
 
DynamicSerDeSimpleNode - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeSimpleNode.
DynamicSerDeSimpleNode(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
DynamicSerDeSimpleNode(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
DynamicSerDeStart - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeStart(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStart
 
DynamicSerDeStart(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStart
 
DynamicSerDeStruct - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeStruct.
DynamicSerDeStruct(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
DynamicSerDeStruct(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
DynamicSerDeStructBase - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeStructBase.
DynamicSerDeStructBase(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
DynamicSerDeStructBase(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
dynamicSerDeStructBaseToObjectInspector(DynamicSerDeTypeBase) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
DynamicSerDeThrows - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeThrows(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeThrows
 
DynamicSerDeThrows(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeThrows
 
DynamicSerDeTypeBase - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeBase.
DynamicSerDeTypeBase(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
DynamicSerDeTypeBase(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
DynamicSerDeTypeBool - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeBool.
DynamicSerDeTypeBool(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
DynamicSerDeTypeBool(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
DynamicSerDeTypeByte - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeByte.
DynamicSerDeTypeByte(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
DynamicSerDeTypeByte(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
DynamicSerDeTypedef - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypedef.
DynamicSerDeTypedef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
DynamicSerDeTypedef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
DynamicSerDeTypeDefinition - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeTypeDefinition(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDefinition
 
DynamicSerDeTypeDefinition(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDefinition
 
DynamicSerDeTypeDouble - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeDouble.
DynamicSerDeTypeDouble(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
DynamicSerDeTypeDouble(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
DynamicSerDeTypei16 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei16.
DynamicSerDeTypei16(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
DynamicSerDeTypei16(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
DynamicSerDeTypei32 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei32.
DynamicSerDeTypei32(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
DynamicSerDeTypei32(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
DynamicSerDeTypei64 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei64.
DynamicSerDeTypei64(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
DynamicSerDeTypei64(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
DynamicSerDeTypeList - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeList.
DynamicSerDeTypeList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
DynamicSerDeTypeList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
DynamicSerDeTypeMap - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeMap.
DynamicSerDeTypeMap(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
DynamicSerDeTypeMap(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
DynamicSerDeTypeSet - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeSet.
DynamicSerDeTypeSet(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
DynamicSerDeTypeSet(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
DynamicSerDeTypeString - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeString.
DynamicSerDeTypeString(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
DynamicSerDeTypeString(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
DynamicSerDeUnflagArgs - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeUnflagArgs(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeUnflagArgs
 
DynamicSerDeUnflagArgs(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeUnflagArgs
 
DynamicSerDeXception - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeXception(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeXception
 
DynamicSerDeXception(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeXception
 

E

edgeProperties - Variable in class org.apache.hadoop.hive.ql.plan.SparkWork
 
elementOffset - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
elementReader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ListTreeReader
 
elementSize - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
elemIndex - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For writes, on what element are we on so we know when to use normal list separator or for a map know when to use the k/v separator.
EmbeddedCLIServiceClient - Class in org.apache.hive.service.cli
EmbeddedCLIServiceClient.
EmbeddedCLIServiceClient(ICLIService) - Constructor for class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
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
 
EmbeddedThriftBinaryCLIService - Class in org.apache.hive.service.cli.thrift
EmbeddedThriftBinaryCLIService.
EmbeddedThriftBinaryCLIService() - Constructor for class org.apache.hive.service.cli.thrift.EmbeddedThriftBinaryCLIService
 
emitErrorMessage(String) - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
EMPTY_TREE - Static variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
The empty tree that can be returned for an empty filter.
emptyList - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
emptyStringArray - Static variable in class org.apache.hive.common.util.HiveStringUtils
 
ENABLE_INDEXES - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated.
ENABLE_JOB_RECONNECT - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
ENABLE_JOB_RECONNECT_DEFAULT - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
ENABLE_LOG - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
enable_tracing() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Enable tracing.
enableJobReconnectDefault() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
enableOpt(int) - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
encodeArray(String[]) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Take an array of strings and encode it into one string.
encodeArray(List<String>) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Encode a List into a string.
encodeBytes(byte[]) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
encodeDelegationTokenInformation(AbstractDelegationTokenSecretManager.DelegationTokenInformation) - Static method in class org.apache.hadoop.security.token.delegation.HiveDelegationTokenSupport
 
encodeWritable(Writable) - Static method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
encoding - Variable in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
 
ENCODING - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
encodingStrategy(OrcFile.EncodingStrategy) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Sets the encoding strategy that is used to encode the data.
end - Variable in class org.apache.hadoop.hive.common.DiskRange
The address afterwards.
end() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
end() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
end() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
end() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Finish the current operation and pop it off of the stack.
endColumn - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
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.CommonMergeJoinOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
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
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
endLine - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endMap(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
endOfCurrentReadBlock() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
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
 
endRecord(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
endScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
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
 
endTimeHasMethod(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
endTimes - Variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
endTreeNode(ExpressionTree.TreeNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
endVector(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
enforceMaxLength(String, int) - Static method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
enforceMaxLength(int) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
enforceMaxLength(int) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
enforcePrecisionScale(BigDecimal, int, int) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
enforcePrecisionScale(HiveDecimal, int, int) - Static method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
enforcePrecisionScale(HiveDecimal, DecimalTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
enforcePrecisionScale(HiveDecimal, int, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
enforcePrecisionScale(HiveDecimalWritable, DecimalTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
enforcePrecisionScale(HiveDecimalWritable, int, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
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
 
enlargeArrays() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Enlarge the size of arrays storing information for the elements inside the array.
EnqueueBean - Class in org.apache.hive.hcatalog.templeton
EnqueueBean - The results of a call that enqueues a Hadoop job.
EnqueueBean() - Constructor for class org.apache.hive.hcatalog.templeton.EnqueueBean
 
EnqueueBean(String) - Constructor for class org.apache.hive.hcatalog.templeton.EnqueueBean
Create a new EnqueueBean.
enqueueController(String, Map<String, Object>, String, List<String>) - Method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
Enqueue the TempletonControllerJob directly calling doAs.
ensureCapacity(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
 
ensureClassExists(String) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
ensureCurrentState(Service.STATE, Service.STATE) - Static method in class org.apache.hive.service.ServiceOperations
Verify that that a service is in a given state.
ensureOrderSpec() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
ensurePath(String, List<ACL>) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
Create a path if it does not already exist ("mkdir -p")
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(Path, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
 
Entity(Database, String, Entity.Type) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
Create an entity representing a object with given name, database namespace and type
Entity.Type - Enum in org.apache.hadoop.hive.ql.hooks
The type of the entity.
ENTRY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
entrySet() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
entrySet() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinPersistableTableContainer
 
entrySet() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Gets the entry set on this structure.
Enum() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
EnumDef() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
EnumDefList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
enumForId(short) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
enumForId(short) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
enumForId(short) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
enumForId(short) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
enumForId(short) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
enumForId(short) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
enumForId(short) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
enumForId(short) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
enumForId(short) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
ENV_PREFIX - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
EnvironmentContext - Class in org.apache.hadoop.hive.metastore.api
 
EnvironmentContext() - Constructor for class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
EnvironmentContext(Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
EnvironmentContext(EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.EnvironmentContext
Performs a deep copy on other.
EnvironmentContext._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
EOF - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
EOF - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
EOF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
EOF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
EOF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
EOF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
EOF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
EOF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
End of File.
eol - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
The end of line string for this machine.
Equal - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to isEqual() over PrimitiveCompare instance.
Equal() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.Equal
 
Equal(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.Equal
 
EQUAL - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
EQUAL - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
EQUAL_NS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
EQUAL_NS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
EQUAL_NS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
EQUAL_NS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
EQUAL_NS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
equalKey(long, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastKeyStore
 
equalKeySeriesAllMatchIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
equalKeySeriesAllMatchIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
equalKeySeriesAllMatchIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
equalKeySeriesDuplicateCounts - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
equalKeySeriesDuplicateCounts - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
equalKeySeriesDuplicateCounts - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
equalKeySeriesHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
equalKeySeriesHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
equalKeySeriesIsSingleValue - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
equalKeySeriesIsSingleValue - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
equalKeySeriesValueCounts - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
equals(Object) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
equals(Object) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
equals(Object) - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
equals(Object) - Method in class org.apache.hadoop.hive.common.DiskRange
 
equals(Object) - Method in class org.apache.hadoop.hive.common.ObjectPair
 
equals(ObjectPair<F, S>) - Method in class org.apache.hadoop.hive.common.ObjectPair
 
equals(Object) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Compares this Decimal128 with the specified Object for equality.
equals(Object) - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
equals(Object) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
equals(Object) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
equals(Object) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
equals(HiveVarchar) - Method in class org.apache.hadoop.hive.common.type.HiveVarchar
 
equals(Object) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
equals(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Specialized version.
equals(Object) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
equals(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Specialized version.
equals(int, int, int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Specialized version.
equals(Object) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
HWIAuth is used in Map(s) the equals method is required.
equals(Object) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Uses the sessionName property to compare to sessions.
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
equals(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
equals(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
equals(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
equals(AddPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
equals(AggrStats) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
equals(AlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
equals(BinaryColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
equals(BooleanColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
equals(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
equals(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
equals(ColumnStatisticsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
equals(ColumnStatisticsDesc) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
equals(ColumnStatisticsObj) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
equals(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
equals(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
equals(ConfigValSecurityException) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
equals(CurrentNotificationEventId) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
equals(Database) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
equals(Date) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
equals(DateColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
equals(Decimal) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
equals(DecimalColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
equals(DoubleColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
equals(DropPartitionsExpr) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
equals(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
equals(DropPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
equals(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
equals(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
equals(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
equals(FireEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
equals(FireEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
equals(Function) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
equals(GetOpenTxnsInfoResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
equals(GetOpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
equals(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
equals(GetPrincipalsInRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
equals(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
equals(GetRoleGrantsForPrincipalResponse) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
equals(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
equals(GrantRevokePrivilegeResponse) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
equals(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
equals(GrantRevokeRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
equals(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
equals(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
equals(HeartbeatTxnRangeResponse) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
equals(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
equals(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
equals(Index) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
equals(IndexAlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
equals(InsertEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
equals(InvalidInputException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
equals(InvalidObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
equals(InvalidOperationException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
equals(InvalidPartitionException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
equals(LockComponent) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
equals(LockRequest) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
equals(LockResponse) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
equals(LongColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
equals(MetaException) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
equals(NoSuchLockException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
equals(NoSuchObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
equals(NoSuchTxnException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
equals(NotificationEvent) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
equals(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
equals(NotificationEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
equals(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
equals(OpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
equals(Order) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
equals(Partition) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
equals(PartitionListComposingSpec) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
equals(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
equals(PartitionsByExprResult) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
equals(PartitionSpec) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
equals(PartitionSpecWithSharedSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
equals(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
equals(PartitionsStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
equals(PartitionWithoutSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
equals(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
equals(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
equals(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
equals(RequestPartsSpec) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
equals(ResourceUri) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
equals(Role) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
equals(RolePrincipalGrant) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
equals(Schema) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
equals(SerDeInfo) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
equals(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
equals(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
equals(ShowCompactResponse) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
equals(ShowCompactResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
equals(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
equals(ShowLocksResponse) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
equals(ShowLocksResponseElement) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
equals(SkewedInfo) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
equals(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
equals(StringColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
equals(Table) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
equals(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
equals(TableStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
equals(ThriftHiveMetastore.abort_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
equals(ThriftHiveMetastore.abort_txn_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
equals(ThriftHiveMetastore.add_dynamic_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
equals(ThriftHiveMetastore.add_dynamic_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
equals(ThriftHiveMetastore.add_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
equals(ThriftHiveMetastore.add_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
equals(ThriftHiveMetastore.add_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
equals(ThriftHiveMetastore.add_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
equals(ThriftHiveMetastore.add_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
equals(ThriftHiveMetastore.add_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
equals(ThriftHiveMetastore.add_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
equals(ThriftHiveMetastore.add_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
equals(ThriftHiveMetastore.add_partitions_pspec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
equals(ThriftHiveMetastore.add_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
equals(ThriftHiveMetastore.add_partitions_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
equals(ThriftHiveMetastore.add_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
equals(ThriftHiveMetastore.alter_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
equals(ThriftHiveMetastore.alter_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
equals(ThriftHiveMetastore.alter_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
equals(ThriftHiveMetastore.alter_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
equals(ThriftHiveMetastore.alter_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
equals(ThriftHiveMetastore.alter_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
equals(ThriftHiveMetastore.alter_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
equals(ThriftHiveMetastore.alter_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
equals(ThriftHiveMetastore.alter_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
equals(ThriftHiveMetastore.alter_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
equals(ThriftHiveMetastore.alter_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
equals(ThriftHiveMetastore.alter_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
equals(ThriftHiveMetastore.alter_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
equals(ThriftHiveMetastore.alter_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
equals(ThriftHiveMetastore.alter_table_with_cascade_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
equals(ThriftHiveMetastore.alter_table_with_cascade_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
equals(ThriftHiveMetastore.alter_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
equals(ThriftHiveMetastore.alter_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
equals(ThriftHiveMetastore.append_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
equals(ThriftHiveMetastore.append_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
equals(ThriftHiveMetastore.append_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
equals(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
equals(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
equals(ThriftHiveMetastore.append_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
equals(ThriftHiveMetastore.append_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
equals(ThriftHiveMetastore.append_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
equals(ThriftHiveMetastore.cancel_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
equals(ThriftHiveMetastore.cancel_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
equals(ThriftHiveMetastore.check_lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
equals(ThriftHiveMetastore.check_lock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
equals(ThriftHiveMetastore.commit_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
equals(ThriftHiveMetastore.commit_txn_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
equals(ThriftHiveMetastore.compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
equals(ThriftHiveMetastore.compact_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
equals(ThriftHiveMetastore.create_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
equals(ThriftHiveMetastore.create_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
equals(ThriftHiveMetastore.create_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
equals(ThriftHiveMetastore.create_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
equals(ThriftHiveMetastore.create_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
equals(ThriftHiveMetastore.create_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
equals(ThriftHiveMetastore.create_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
equals(ThriftHiveMetastore.create_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
equals(ThriftHiveMetastore.create_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
equals(ThriftHiveMetastore.create_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
equals(ThriftHiveMetastore.create_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
equals(ThriftHiveMetastore.create_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
equals(ThriftHiveMetastore.delete_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
equals(ThriftHiveMetastore.delete_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
equals(ThriftHiveMetastore.delete_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
equals(ThriftHiveMetastore.delete_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
equals(ThriftHiveMetastore.drop_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
equals(ThriftHiveMetastore.drop_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
equals(ThriftHiveMetastore.drop_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
equals(ThriftHiveMetastore.drop_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
equals(ThriftHiveMetastore.drop_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
equals(ThriftHiveMetastore.drop_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
equals(ThriftHiveMetastore.drop_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
equals(ThriftHiveMetastore.drop_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
equals(ThriftHiveMetastore.drop_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
equals(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
equals(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
equals(ThriftHiveMetastore.drop_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
equals(ThriftHiveMetastore.drop_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
equals(ThriftHiveMetastore.drop_partition_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
equals(ThriftHiveMetastore.drop_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
equals(ThriftHiveMetastore.drop_partitions_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
equals(ThriftHiveMetastore.drop_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
equals(ThriftHiveMetastore.drop_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
equals(ThriftHiveMetastore.drop_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
equals(ThriftHiveMetastore.drop_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
equals(ThriftHiveMetastore.drop_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
equals(ThriftHiveMetastore.drop_table_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
equals(ThriftHiveMetastore.drop_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
equals(ThriftHiveMetastore.drop_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
equals(ThriftHiveMetastore.exchange_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
equals(ThriftHiveMetastore.exchange_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
equals(ThriftHiveMetastore.fire_listener_event_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
equals(ThriftHiveMetastore.fire_listener_event_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
equals(ThriftHiveMetastore.get_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
equals(ThriftHiveMetastore.get_aggr_stats_for_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
equals(ThriftHiveMetastore.get_all_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
equals(ThriftHiveMetastore.get_all_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
equals(ThriftHiveMetastore.get_all_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
equals(ThriftHiveMetastore.get_all_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
equals(ThriftHiveMetastore.get_config_value_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
equals(ThriftHiveMetastore.get_config_value_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
equals(ThriftHiveMetastore.get_current_notificationEventId_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
equals(ThriftHiveMetastore.get_current_notificationEventId_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
equals(ThriftHiveMetastore.get_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
equals(ThriftHiveMetastore.get_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
equals(ThriftHiveMetastore.get_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
equals(ThriftHiveMetastore.get_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
equals(ThriftHiveMetastore.get_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
equals(ThriftHiveMetastore.get_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
equals(ThriftHiveMetastore.get_fields_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
equals(ThriftHiveMetastore.get_fields_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
equals(ThriftHiveMetastore.get_fields_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
equals(ThriftHiveMetastore.get_fields_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
equals(ThriftHiveMetastore.get_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
equals(ThriftHiveMetastore.get_function_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
equals(ThriftHiveMetastore.get_functions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
equals(ThriftHiveMetastore.get_functions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
equals(ThriftHiveMetastore.get_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
equals(ThriftHiveMetastore.get_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
equals(ThriftHiveMetastore.get_index_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
equals(ThriftHiveMetastore.get_index_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
equals(ThriftHiveMetastore.get_indexes_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
equals(ThriftHiveMetastore.get_indexes_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
equals(ThriftHiveMetastore.get_next_notification_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
equals(ThriftHiveMetastore.get_next_notification_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
equals(ThriftHiveMetastore.get_open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
equals(ThriftHiveMetastore.get_open_txns_info_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
equals(ThriftHiveMetastore.get_open_txns_info_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
equals(ThriftHiveMetastore.get_open_txns_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
equals(ThriftHiveMetastore.get_part_specs_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
equals(ThriftHiveMetastore.get_part_specs_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
equals(ThriftHiveMetastore.get_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
equals(ThriftHiveMetastore.get_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
equals(ThriftHiveMetastore.get_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
equals(ThriftHiveMetastore.get_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
equals(ThriftHiveMetastore.get_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
equals(ThriftHiveMetastore.get_partition_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
equals(ThriftHiveMetastore.get_partition_names_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
equals(ThriftHiveMetastore.get_partition_names_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
equals(ThriftHiveMetastore.get_partition_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
equals(ThriftHiveMetastore.get_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
equals(ThriftHiveMetastore.get_partition_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
equals(ThriftHiveMetastore.get_partition_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
equals(ThriftHiveMetastore.get_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
equals(ThriftHiveMetastore.get_partitions_by_expr_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
equals(ThriftHiveMetastore.get_partitions_by_expr_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
equals(ThriftHiveMetastore.get_partitions_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
equals(ThriftHiveMetastore.get_partitions_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
equals(ThriftHiveMetastore.get_partitions_by_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
equals(ThriftHiveMetastore.get_partitions_by_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
equals(ThriftHiveMetastore.get_partitions_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
equals(ThriftHiveMetastore.get_partitions_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
equals(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
equals(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
equals(ThriftHiveMetastore.get_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
equals(ThriftHiveMetastore.get_partitions_pspec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
equals(ThriftHiveMetastore.get_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
equals(ThriftHiveMetastore.get_partitions_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
equals(ThriftHiveMetastore.get_partitions_statistics_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
equals(ThriftHiveMetastore.get_partitions_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
equals(ThriftHiveMetastore.get_partitions_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
equals(ThriftHiveMetastore.get_principals_in_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
equals(ThriftHiveMetastore.get_principals_in_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
equals(ThriftHiveMetastore.get_privilege_set_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
equals(ThriftHiveMetastore.get_privilege_set_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
equals(ThriftHiveMetastore.get_role_grants_for_principal_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
equals(ThriftHiveMetastore.get_role_grants_for_principal_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
equals(ThriftHiveMetastore.get_role_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
equals(ThriftHiveMetastore.get_role_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
equals(ThriftHiveMetastore.get_schema_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
equals(ThriftHiveMetastore.get_schema_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
equals(ThriftHiveMetastore.get_schema_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
equals(ThriftHiveMetastore.get_schema_with_environment_context_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
equals(ThriftHiveMetastore.get_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
equals(ThriftHiveMetastore.get_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
equals(ThriftHiveMetastore.get_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
equals(ThriftHiveMetastore.get_table_names_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
equals(ThriftHiveMetastore.get_table_names_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
equals(ThriftHiveMetastore.get_table_objects_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
equals(ThriftHiveMetastore.get_table_objects_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
equals(ThriftHiveMetastore.get_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
equals(ThriftHiveMetastore.get_table_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
equals(ThriftHiveMetastore.get_table_statistics_req_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
equals(ThriftHiveMetastore.get_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
equals(ThriftHiveMetastore.get_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
equals(ThriftHiveMetastore.get_type_all_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
equals(ThriftHiveMetastore.get_type_all_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
equals(ThriftHiveMetastore.get_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
equals(ThriftHiveMetastore.get_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
equals(ThriftHiveMetastore.getMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
equals(ThriftHiveMetastore.getMetaConf_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
equals(ThriftHiveMetastore.grant_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
equals(ThriftHiveMetastore.grant_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
equals(ThriftHiveMetastore.grant_revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
equals(ThriftHiveMetastore.grant_revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
equals(ThriftHiveMetastore.grant_revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
equals(ThriftHiveMetastore.grant_revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
equals(ThriftHiveMetastore.grant_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
equals(ThriftHiveMetastore.grant_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
equals(ThriftHiveMetastore.heartbeat_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
equals(ThriftHiveMetastore.heartbeat_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
equals(ThriftHiveMetastore.heartbeat_txn_range_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
equals(ThriftHiveMetastore.heartbeat_txn_range_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
equals(ThriftHiveMetastore.isPartitionMarkedForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
equals(ThriftHiveMetastore.isPartitionMarkedForEvent_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
equals(ThriftHiveMetastore.list_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
equals(ThriftHiveMetastore.list_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
equals(ThriftHiveMetastore.list_roles_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
equals(ThriftHiveMetastore.list_roles_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
equals(ThriftHiveMetastore.lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
equals(ThriftHiveMetastore.lock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
equals(ThriftHiveMetastore.markPartitionForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
equals(ThriftHiveMetastore.markPartitionForEvent_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
equals(ThriftHiveMetastore.open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
equals(ThriftHiveMetastore.open_txns_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
equals(ThriftHiveMetastore.partition_name_has_valid_characters_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
equals(ThriftHiveMetastore.partition_name_has_valid_characters_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
equals(ThriftHiveMetastore.partition_name_to_spec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
equals(ThriftHiveMetastore.partition_name_to_spec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
equals(ThriftHiveMetastore.partition_name_to_vals_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
equals(ThriftHiveMetastore.partition_name_to_vals_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
equals(ThriftHiveMetastore.rename_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
equals(ThriftHiveMetastore.rename_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
equals(ThriftHiveMetastore.renew_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
equals(ThriftHiveMetastore.renew_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
equals(ThriftHiveMetastore.revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
equals(ThriftHiveMetastore.revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
equals(ThriftHiveMetastore.revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
equals(ThriftHiveMetastore.revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
equals(ThriftHiveMetastore.set_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
equals(ThriftHiveMetastore.set_aggr_stats_for_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
equals(ThriftHiveMetastore.set_ugi_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
equals(ThriftHiveMetastore.set_ugi_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
equals(ThriftHiveMetastore.setMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
equals(ThriftHiveMetastore.setMetaConf_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
equals(ThriftHiveMetastore.show_compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
equals(ThriftHiveMetastore.show_compact_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
equals(ThriftHiveMetastore.show_locks_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
equals(ThriftHiveMetastore.show_locks_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
equals(ThriftHiveMetastore.unlock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
equals(ThriftHiveMetastore.unlock_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
equals(ThriftHiveMetastore.update_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
equals(ThriftHiveMetastore.update_partition_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
equals(ThriftHiveMetastore.update_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
equals(ThriftHiveMetastore.update_table_column_statistics_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
equals(TxnAbortedException) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
equals(TxnInfo) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
equals(TxnOpenException) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
equals(Type) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
equals(UnknownDBException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
equals(UnknownPartitionException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
equals(UnknownTableException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
equals(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
equals(Version) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
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.MapJoinKeyObject
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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.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.calcite.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.api.Adjacency
 
equals(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
equals(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
equals(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
equals(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
equals(QueryPlan) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
equals(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
equals(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
equals(Object) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
equals(InnerStruct) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
equals(Object) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
equals(ThriftTestObj) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
equals(Object) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
equals(LazyObjectInspectorParametersImpl) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableVoidObjectInspector
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
equals(Complex) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
equals(IntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
equals(MegaStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
equals(MiniStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
equals(PropValueUnion) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
equals(SetIntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
equals(HiveClusterStatus) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
equals(Object) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
equals(HiveServerException) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
equals(ThriftHive.clean_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
equals(ThriftHive.clean_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
equals(ThriftHive.execute_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
equals(ThriftHive.execute_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
equals(ThriftHive.fetchAll_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
equals(ThriftHive.fetchAll_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
equals(ThriftHive.fetchN_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
equals(ThriftHive.fetchN_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
equals(ThriftHive.fetchOne_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
equals(ThriftHive.fetchOne_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
equals(ThriftHive.getClusterStatus_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
equals(ThriftHive.getClusterStatus_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
equals(ThriftHive.getQueryPlan_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
equals(ThriftHive.getQueryPlan_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
equals(ThriftHive.getSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
equals(ThriftHive.getSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
equals(ThriftHive.getThriftSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
equals(ThriftHive.getThriftSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
equals(Object) - Method in class org.apache.hive.hcatalog.data.Pair
 
equals(Object) - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
equals(Object) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
equals(Object) - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
equals(Object) - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.ColumnDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.SerdeDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.StorageFormatDesc
 
equals(Object) - Method in class org.apache.hive.hcatalog.templeton.TableDesc.StoredByDesc
 
equals(Object) - Method in class org.apache.hive.service.cli.Handle
 
equals(Object) - Method in class org.apache.hive.service.cli.HandleIdentifier
 
equals(Object) - Method in class org.apache.hive.service.cli.OperationHandle
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
equals(TArrayTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
equals(TBinaryColumn) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
equals(TBoolColumn) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
equals(TBoolValue) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
equals(TByteColumn) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
equals(TByteValue) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
equals(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
equals(TCancelDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
equals(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
equals(TCancelOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
equals(TCLIService.CancelDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
equals(TCLIService.CancelDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
equals(TCLIService.CancelOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
equals(TCLIService.CancelOperation_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
equals(TCLIService.CloseOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
equals(TCLIService.CloseOperation_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
equals(TCLIService.CloseSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
equals(TCLIService.CloseSession_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
equals(TCLIService.ExecuteStatement_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
equals(TCLIService.ExecuteStatement_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
equals(TCLIService.FetchResults_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
equals(TCLIService.FetchResults_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
equals(TCLIService.GetCatalogs_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
equals(TCLIService.GetCatalogs_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
equals(TCLIService.GetColumns_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
equals(TCLIService.GetColumns_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
equals(TCLIService.GetDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
equals(TCLIService.GetDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
equals(TCLIService.GetFunctions_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
equals(TCLIService.GetFunctions_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
equals(TCLIService.GetInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
equals(TCLIService.GetInfo_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
equals(TCLIService.GetOperationStatus_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
equals(TCLIService.GetOperationStatus_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
equals(TCLIService.GetResultSetMetadata_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
equals(TCLIService.GetResultSetMetadata_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
equals(TCLIService.GetSchemas_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
equals(TCLIService.GetSchemas_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
equals(TCLIService.GetTables_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
equals(TCLIService.GetTables_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
equals(TCLIService.GetTableTypes_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
equals(TCLIService.GetTableTypes_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
equals(TCLIService.GetTypeInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
equals(TCLIService.GetTypeInfo_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
equals(TCLIService.OpenSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
equals(TCLIService.OpenSession_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
equals(TCLIService.RenewDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
equals(TCLIService.RenewDelegationToken_result) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
equals(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
equals(TCloseOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
equals(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
equals(TCloseSessionResp) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
equals(TColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
equals(TColumnDesc) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
equals(TColumnValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
equals(TDoubleColumn) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
equals(TDoubleValue) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
equals(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
equals(TExecuteStatementResp) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
equals(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
equals(TFetchResultsResp) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
equals(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
equals(TGetCatalogsResp) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
equals(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
equals(TGetColumnsResp) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
equals(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
equals(TGetDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
equals(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
equals(TGetFunctionsResp) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
equals(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
equals(TGetInfoResp) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
equals(TGetInfoValue) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
equals(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
equals(TGetOperationStatusResp) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
equals(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
equals(TGetResultSetMetadataResp) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
equals(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
equals(TGetSchemasResp) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
equals(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
equals(TGetTablesResp) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
equals(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
equals(TGetTableTypesResp) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
equals(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
equals(TGetTypeInfoResp) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
equals(THandleIdentifier) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
equals(TI16Column) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
equals(TI16Value) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
equals(TI32Column) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
equals(TI32Value) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
equals(TI64Column) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
equals(TI64Value) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
equals(TMapTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
equals(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
equals(TOpenSessionResp) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
equals(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
equals(TPrimitiveTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
equals(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
equals(TRenewDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TRow
 
equals(TRow) - Method in class org.apache.hive.service.cli.thrift.TRow
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
equals(TRowSet) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
equals(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
equals(TStatus) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
equals(TStringColumn) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
equals(TStringValue) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
equals(TStructTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
equals(TTableSchema) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
equals(TTypeDesc) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
equals(TTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
equals(TTypeQualifiers) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
equals(TTypeQualifierValue) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
equals(TUnionTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
equals(Object) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
equals(TUserDefinedTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
equalsFileSystem(FileSystem, FileSystem) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
err - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
errMsg - Static variable in class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
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
 
ERROR - Static variable in class org.apache.hive.hcatalog.data.DataType
 
ErrorAndSolution - Class in org.apache.hadoop.hive.ql.exec.errors
Immutable class for storing a possible error and a resolution suggestion.
errorcode - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
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 - Variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
ErrorMsg - Enum in org.apache.hadoop.hive.ql
List of all error messages.
ErrorType - Enum in org.apache.hive.hcatalog.common
Enum type representing the various errors throws by HCat.
ESCAPE - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
ESCAPE_CHAR - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
ESCAPE_CHAR - Static variable in class org.apache.hive.common.util.HiveStringUtils
 
escapeChar - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
ESCAPECHAR - Static variable in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
escapeChar(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
escapeChar(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
escaped - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
ESCAPED_ASERTISK_REGEX - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
ESCAPED_ASTERISK - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
ESCAPED_COLON - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
ESCAPED_COLON_REGEX - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
escapedNull - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
The escaped byte sequence for the null byte.
escapedOne - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
The escaped byte sequence for the "\1" byte.
escapeHTML(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Escapes HTML Special characters present in the string.
escapePathName(String) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
escapePathName(String, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
Escapes a path name.
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.
escapeSQLString(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Escapes the string for AST; doesn't enclose it in quotes, however.
escapeString(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
escapeString(String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Escape a String in JSON format.
escapeString(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Escape commas in the string using the default escape char
escapeString(String, char, char) - Static method in class org.apache.hive.common.util.HiveStringUtils
Escape charToEscape in the string with the escape char escapeChar
escapeString(String, char, char[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
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.GenericUDAFDateStatsEvaluator.DateStatsAgg
 
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.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
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
 
estimateParsedLength() - Method in class org.apache.hive.common.util.TimestampParser.MillisDateFormatParser
 
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.calcite.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.
ETypeConverter.BinaryConverter<T extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
ETypeConverter.BinaryConverter(PrimitiveType, ConverterParent, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
eval - Variable in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
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(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.contrib.genericudf.example.GenericUDFDBOutput
 
evaluate(Integer...) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleAdd
 
evaluate(Double...) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleAdd
 
evaluate(List<Double>) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleArraySum
 
evaluate(String, Object...) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleFormat
 
evaluate(Map<String, String>) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleMapConcat
 
evaluate(Object) - Method in class org.apache.hadoop.hive.contrib.udf.example.UDFExampleStructPrint
 
evaluate() - Method in class org.apache.hadoop.hive.contrib.udf.UDFRowSequence
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Evaluate the expression given the row.
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.CastStringToIntervalDayTime
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.gen.CastDateToBooleanViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarAddDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarDivideDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarModuloDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarMultiplyDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarSubtractDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.IfExprStringGroupColumnStringGroupColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
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.StringGroupColConcatStringScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
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.StringScalarConcatStringGroupCol
 
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.VectorElt
 
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.GenericUDFAddMonths
 
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.GenericUDFBaseArithmetic
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(HiveDecimal, HiveDecimal) - 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.GenericUDFCbrt
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCeil
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCeil
 
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.GenericUDFCurrentDate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
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.GenericUDFDateFormat
 
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.GenericUDFFactorial
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloor
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloor
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
evaluate(HiveDecimalWritable) - 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.GenericUDFGreatest
 
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.GenericUDFInitCap
 
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.GenericUDFLastDay
 
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.GenericUDFLevenshtein
 
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.GenericUDFMonthsBetween
 
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.GenericUDFNextDay
 
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(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
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(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
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(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
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(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
evaluate(HiveDecimal, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
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.GenericUDFSoundex
 
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.GenericUDFToIntervalDayTime
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToIntervalYearMonth
 
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.GenericUDFTrunc
 
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(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFAscii
 
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(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(HiveIntervalDayTimeWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFE
 
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(HiveIntervalDayTimeWritable) - 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, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the logarithm of "a" with base "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.UDFMath
Returns null if the passed in value is and passes on to UDFMath.doEvaluate(DoubleWritable) if not.
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(HiveIntervalDayTimeWritable) - 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(HiveIntervalYearMonthWritable) - 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, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftLeft
 
evaluate(ShortWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftLeft
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftLeft
 
evaluate(LongWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftLeft
 
evaluate(ByteWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRight
 
evaluate(ShortWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRight
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRight
 
evaluate(LongWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRight
 
evaluate(ByteWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRightUnsigned
 
evaluate(ShortWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRightUnsigned
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRightUnsigned
 
evaluate(LongWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRightUnsigned
 
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() - 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(HiveIntervalDayTimeWritable) - 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(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSpace
 
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(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(RecordIdentifier) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert a RecordIdentifier.
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(HiveIntervalYearMonthWritable) - 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
evaluateChildren(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Evaluate the child expressions on the given input batch.
evaluateDate(ColumnVector, int, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
evaluateDate(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
evaluateDate(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
evaluateDate(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
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.gen.VectorUDAFAvgDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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
 
evaluateResponse(byte[]) - Method in class org.apache.hive.service.auth.PlainSaslServer
 
evaluateString(BytesColumnVector, LongColumnVector, BytesColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
evaluateString(ColumnVector, BytesColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
evaluateString(ColumnVector, LongColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
evaluateString(ColumnVector, LongColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
evaluateTimestamp(ColumnVector, int, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
evaluateTimestamp(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
evaluateTimestamp(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
evaluateTimestamp(ColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
event - Variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
EventCleanerTask - Class in org.apache.hadoop.hive.metastore.events
 
EventCleanerTask(HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.EventCleanerTask
 
eventOperatorSet - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
eventOpToTableScanMap - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
EventRequestType - Enum in org.apache.hadoop.hive.metastore.api
 
eventType - Variable in class org.apache.hive.hcatalog.messaging.HCatEventMessage
 
exceedsTenToThirtyEight() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Returns if we overflowed 10**38, but not 2**128.
exception - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
exception(Exception) - Method in interface org.apache.hadoop.hive.ql.security.authorization.AuthorizationFactory.AuthorizationExceptionHandler
 
exception(Exception) - Method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationFactory.DefaultAuthorizationExceptionHandler
 
EXCEPTION_MESSAGE - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hive.spark.client.rpc.RpcDispatcher
 
exceptions - Variable in class org.apache.hadoop.hive.common.ValidReadTxnList
 
EXCHANGE_BELOW_JOIN - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule
Rule that creates Exchange operators under a Join operator.
EXCHANGE_BELOW_MULTIJOIN - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule
Rule that creates Exchange operators under a MultiJoin operator.
exchange_partition(Map<String, String>, String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.exchange_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
exchange_partition(Map<String, String>, String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.exchange_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
exchange_partition(Map<String, String>, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
exchange_partition(Map<String, String>, String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
exchange_partition(Map<String, String>, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
exchange_partition(Map<String, String>, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Exchange the partition between two tables
exchange_partition(Map<String, String>, String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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
 
exec(JobContext, Partition, Path) - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
EXEC_ENCODING_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
EXEC_ENVS_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
EXEC_MAX_BYTES_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
EXEC_MAX_PROCS_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
EXEC_TIMEOUT_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
ExecBean - Class in org.apache.hive.hcatalog.templeton
ExecBean - The results of an exec call.
ExecBean() - Constructor for class org.apache.hive.hcatalog.templeton.ExecBean
 
ExecBean(String, String, int) - Constructor for class org.apache.hive.hcatalog.templeton.ExecBean
Create a new ExecBean.
execBean - Variable in exception org.apache.hive.hcatalog.templeton.HcatException
 
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.
execEnv(Map<String, String>) - Method in class org.apache.hive.hcatalog.templeton.ExecServiceImpl
Build the environment used for all exec calls.
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, Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecMapper.ReportStats
 
ExecMapperContext - Class in org.apache.hadoop.hive.ql.exec.mr
 
ExecMapperContext(JobConf) - 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
 
ExecService - Interface in org.apache.hive.hcatalog.templeton
 
execService - Static variable in class org.apache.hive.hcatalog.templeton.Server
 
ExecServiceImpl - Class in org.apache.hive.hcatalog.templeton
Execute a local program.
execStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
execString - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-e option if any that the session has been invoked with.
execute() - Method in class org.apache.hadoop.hive.ant.GenHiveTemplate
 
execute() - Method in class org.apache.hadoop.hive.ant.GenVectorCode
 
execute() - Method in class org.apache.hadoop.hive.ant.GetVersionPref
Executes the ant task .
execute() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
execute() - Method in class org.apache.hadoop.hive.common.cli.ShellCmdExecutor
 
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.ColumnStatsUpdateTask
 
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.ExplainSQRewriteTask
 
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, SparkWork) - Method in interface org.apache.hadoop.hive.ql.exec.spark.HiveSparkClient
HiveSparkClient should generate Spark RDD graph by given sparkWork and driverContext, and submit RDD graph to Spark cluster.
execute(DriverContext, SparkWork) - Method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
execute(DriverContext, SparkWork) - Method in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkTask
 
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.Task
This method is overridden in each Task.
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileTask
start a new map-reduce job to do the merge, almost the same as ExecDriver.
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.PTFPartitionIterator<Object>, PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
execute(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop
 
execute(PTFPartition.PTFPartitionIterator<Object>, PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop
 
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.TableFunctionEvaluator
 
execute(PTFPartition.PTFPartitionIterator<Object>, PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
execute(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
execute(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
execute(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
execute(String) - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
execute(String) - Method in class org.apache.hive.beeline.ReflectiveCommandHandler
 
execute() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
execute(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
execute(String, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
execute(String, int[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
execute(String, String[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
execute() - Method in class org.apache.hive.jdbc.HivePreparedStatement
Invokes executeQuery(sql) using the sql provided to the constructor.
execute(String) - Method in class org.apache.hive.jdbc.HiveStatement
 
execute(String, int) - Method in class org.apache.hive.jdbc.HiveStatement
 
execute(String, int[]) - Method in class org.apache.hive.jdbc.HiveStatement
 
execute(String, String[]) - Method in class org.apache.hive.jdbc.HiveStatement
 
executeBatch() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeBatch() - Method in class org.apache.hive.jdbc.HiveStatement
 
executeInChildVM(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
executeInProcess(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
executeJDOQLSelect(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following API - executeJDOQLSelect is used by HiveMetaTool.
executeJDOQLUpdate(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following API - executeJDOQLUpdate is used by HiveMetaTool.
executeQuery() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeQuery(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeQuery() - Method in class org.apache.hive.jdbc.HivePreparedStatement
Invokes executeQuery(sql) using the sql provided to the constructor.
executeQuery(String) - Method in class org.apache.hive.jdbc.HiveStatement
 
executeSetVariable(String, String) - Method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
executeStatement(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.CLIService
 
executeStatement(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
executeStatement(SessionHandle, String, Map<String, String>) - Method in interface org.apache.hive.service.cli.ICLIService
 
executeStatement(String, Map<String, String>) - Method in interface org.apache.hive.service.cli.session.HiveSession
execute operation handler
executeStatement(String, Map<String, String>) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
ExecuteStatement(TExecuteStatementReq, AsyncMethodCallback<TCLIService.AsyncClient.ExecuteStatement_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
ExecuteStatement(TExecuteStatementReq, AsyncMethodCallback<TCLIService.AsyncClient.ExecuteStatement_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
ExecuteStatement(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
ExecuteStatement(TExecuteStatementReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
ExecuteStatement(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
executeStatement(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
executeStatementAsync(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.CLIService
 
executeStatementAsync(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
executeStatementAsync(SessionHandle, String, Map<String, String>) - Method in interface org.apache.hive.service.cli.ICLIService
 
executeStatementAsync(String, Map<String, String>) - Method in interface org.apache.hive.service.cli.session.HiveSession
execute operation handler
executeStatementAsync(String, Map<String, String>) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
executeStatementAsync(SessionHandle, String, Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
ExecuteStatementOperation - Class in org.apache.hive.service.cli.operation
 
ExecuteStatementOperation(HiveSession, String, Map<String, String>, boolean) - Constructor for class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
executeTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
This method is called in the Driver on every task.
executeUpdate() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeUpdate(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, int[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, String[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
executeUpdate() - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
executeUpdate(String) - Method in class org.apache.hive.jdbc.HiveStatement
 
executeUpdate(String, int) - Method in class org.apache.hive.jdbc.HiveStatement
 
executeUpdate(String, int[]) - Method in class org.apache.hive.jdbc.HiveStatement
 
executeUpdate(String, String[]) - Method in class org.apache.hive.jdbc.HiveStatement
 
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, long, 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).
executorDeserializeTime - Variable in class org.apache.hive.spark.client.metrics.Metrics
Time taken on the executor to deserialize tasks.
executorRunTime - Variable in class org.apache.hive.spark.client.metrics.Metrics
Time the executor spends actually running the task (including fetching shuffle data).
EximReplicationTaskFactory - Class in org.apache.hive.hcatalog.api.repl.exim
EXIMReplicationTaskFactory is an export-import based ReplicationTask.Factory.
EximReplicationTaskFactory() - Constructor for class org.apache.hive.hcatalog.api.repl.exim.EximReplicationTaskFactory
 
EximUtil - Class in org.apache.hadoop.hive.ql.parse
EximUtil.
EximUtil.ReadMetaData - Class in org.apache.hadoop.hive.ql.parse
Utility class to help return complex value from readMetaData function
EximUtil.ReadMetaData() - Constructor for class org.apache.hadoop.hive.ql.parse.EximUtil.ReadMetaData
 
EximUtil.ReadMetaData(Table, Iterable<Partition>, ReplicationSpec) - Constructor for class org.apache.hadoop.hive.ql.parse.EximUtil.ReadMetaData
 
existingTable - Variable in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
exists(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
existsTable() - Method in class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
exit() - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
exit() - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
EXIT_FNAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
exitcode - Variable in class org.apache.hive.hcatalog.templeton.ExecBean
 
exitVal - Variable in class org.apache.hadoop.hive.ql.exec.TaskResult
 
exitValue - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
expandAndRehashToTarget(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
ExpandBuff(boolean) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
expectedTokenSequences - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
Each entry in this array is an array of integers.
EXPL_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
explain - Variable in class org.apache.hadoop.hive.ql.Context
 
Explain - Annotation Type in org.apache.hadoop.hive.ql.plan
Explain.
Explain.Level - Enum in org.apache.hadoop.hive.ql.plan
 
explainLogical - Variable in class org.apache.hadoop.hive.ql.Context
 
explainNoCompute() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
explainOption() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ExplainSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ExplainSemanticAnalyzer.
ExplainSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
ExplainSQRewriteSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
ExplainSQRewriteSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExplainSQRewriteSemanticAnalyzer
 
ExplainSQRewriteTask - Class in org.apache.hadoop.hive.ql.exec
 
ExplainSQRewriteTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainSQRewriteTask
 
ExplainSQRewriteWork - Class in org.apache.hadoop.hive.ql.plan
 
ExplainSQRewriteWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ExplainSQRewriteWork
 
ExplainSQRewriteWork(String, QB, ASTNode, Context) - Constructor for class org.apache.hadoop.hive.ql.plan.ExplainSQRewriteWork
 
explainStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
explainTerms(RelWriter) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
explainTerms(RelWriter) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
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, BaseSemanticAnalyzer, boolean, boolean, boolean, boolean, boolean, boolean, String) - 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
 
Exponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Exponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Exponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
Exponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Exponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
exponentialBackoff(List<HiveCalciteUtil.JoinLeafPredicateInfo>, ImmutableMap<Integer, Double>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
ExportCommand - Class in org.apache.hive.hcatalog.api.repl.commands
 
ExportCommand(String, String, Map<String, String>, String, boolean, long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
ExportCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
exportCounters(AbstractMap<String, Long>) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionListener
 
exportedkeys(String) - Method in class org.apache.hive.beeline.Commands
 
ExportSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ExportSemanticAnalyzer.
ExportSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExportSemanticAnalyzer
 
exportStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
expression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
expressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
expressions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expressions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
expressionsInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expressionsInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
expressionsNotInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expressionsNotInParenthese() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
ExpressionTree - Class in org.apache.hadoop.hive.metastore.parser
The Class representing the filter as a binary tree.
ExpressionTree() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree
 
ExpressionTree.ANTLRNoCaseStringStream - Class in org.apache.hadoop.hive.metastore.parser
Case insensitive ANTLR string stream
ExpressionTree.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.ANTLRNoCaseStringStream
 
ExpressionTree.FilterBuilder - Class in org.apache.hadoop.hive.metastore.parser
Helper class that wraps the stringbuilder used to build the filter over the tree, as well as error propagation in two modes - expect errors, i.e.
ExpressionTree.FilterBuilder(boolean) - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
ExpressionTree.LeafNode - Class in org.apache.hadoop.hive.metastore.parser
The Class representing the leaf level nodes in the ExpressionTree.
ExpressionTree.LeafNode() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
ExpressionTree.LogicalOperator - Enum in org.apache.hadoop.hive.metastore.parser
The logical operations supported.
ExpressionTree.Operator - Enum in org.apache.hadoop.hive.metastore.parser
The operators supported.
ExpressionTree.TreeNode - Class in org.apache.hadoop.hive.metastore.parser
The Class representing a Node in the ExpressionTree.
ExpressionTree.TreeNode() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
ExpressionTree.TreeNode(ExpressionTree.TreeNode, ExpressionTree.LogicalOperator, ExpressionTree.TreeNode) - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
ExpressionTree.TreeVisitor - Class in org.apache.hadoop.hive.metastore.parser
Depth first traversal of ExpressionTree.
ExpressionTree.TreeVisitor() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
ExprNodeColumnDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeColumnDesc.
ExprNodeColumnDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(ColumnInfo) - 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
 
ExprNodeConverter - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
ExprNodeConverter(String, RelDataType, Set<Integer>, RelDataTypeFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
ExprNodeConverter(String, String, RelDataType, RelDataType, Set<Integer>, RelDataTypeFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
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
 
ExprNodeDynamicListDesc - Class in org.apache.hadoop.hive.ql.plan
This expression represents a list that will be available at runtime.
ExprNodeDynamicListDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
ExprNodeDynamicListDesc(TypeInfo, Operator<? extends OperatorDesc>, int) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
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
 
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
 
exprs(List<DropPartitionsExpr>) - Static method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
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>) - 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
 
extendedBooleanLiteral - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
extendedToString() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
Extends() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
external - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
external - Variable in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
extract() - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListCreateHelper
 
extract() - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListMutateHelper
 
extractChildJobId(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Extract the job id from jar jobs.
extractColumnInfo() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
Extracts and set column names and column types from the table properties
extractComparePair(ExprNodeDesc, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
ExtractDate(String) - Static method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
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
 
extractFieldObjectInspectors(Class<?>, ObjectInspectorFactory.ObjectInspectorOptions) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
extractFields(ExprNodeFieldDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Extract fields from the given node descriptor
extractHiInt(long) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
 
extractLowInt(long) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
 
extractOpTree() - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
extractPartitionPredicates(RelOptCluster, RelOptHiveTable, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune
Breaks the predicate into 2 pieces.
extractPercentComplete(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Extract the percent complete line from Pig or Jar jobs.
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.
extractRow(int, Object[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
extractRowColumn(int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
extractSchema(Table) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
extractSchema(Partition) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
extractStagesAndPlans() - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
extractSubset(int, int) - Method in class org.apache.hive.service.cli.Column
 
extractSubset(int) - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
extractSubset(int) - Method in class org.apache.hive.service.cli.RowBasedSet
 
extractSubset(int) - Method in interface org.apache.hive.service.cli.RowSet
 
extractThriftToken(String, String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
extractVertex(JSONObject) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Stage
 
extraFieldsCheck() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
extraFieldsCheck() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
extraFieldsCheck() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
extraFieldsCheck() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
extrapolate(Object[], Object[], int, Map<String, Integer>) - Method in interface org.apache.hadoop.hive.metastore.IExtrapolatePartStatus
 
extrapolate(Object[], Object[], int, Map<String, Integer>) - Method in class org.apache.hadoop.hive.metastore.LinearExtrapolatePartStatus
 

F

FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
FAILURE_HOOK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
FairSchedulerShim - Class in org.apache.hadoop.hive.schshim
 
FairSchedulerShim() - Constructor for class org.apache.hadoop.hive.schshim.FairSchedulerShim
 
FALSE - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
falseBytes - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
familyName - Variable in class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
The column family name
fastSerializeForHiveDecimal(Decimal128FastBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serializes the value in a format compatible with the BigDecimal's own representation
fastSerializeForHiveDecimal(Decimal128FastBuffer, byte) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
fastStats - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
fastUpdateFromInternalStorage(byte[], short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Fats update from BigInteger two's complement representation
fastUpdateFromInternalStorage(byte[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates this value from a serialized unscaled BigInteger representation.
feedSubscribers - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
fetch(List) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
FETCH_OPERATOR_DIRECTORY_LIST - Static variable in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
fetchAll(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchAll(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchAll() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchAll() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
fetchColumns(JobConf, Set<Pair<Text, Text>>) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
FetchConverter - Class in org.apache.hadoop.hive.common.io
 
FetchConverter(OutputStream, boolean, String) - Constructor for class org.apache.hadoop.hive.common.io.FetchConverter
 
fetchFinished() - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
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
 
fetchN(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchN(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchN(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchN(int) - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
fetchOne(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchOne(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchOne() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchOne() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
FetchOperator - Class in org.apache.hadoop.hive.ql.exec
FetchTask implementation.
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
 
FetchOrientation - Enum in org.apache.hive.service.cli
FetchOrientation.
fetchResults(OperationHandle) - Method in class org.apache.hive.service.cli.CLIService
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in class org.apache.hive.service.cli.CLIService
 
fetchResults(OperationHandle) - Method in class org.apache.hive.service.cli.CLIServiceClient
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
fetchResults(OperationHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in interface org.apache.hive.service.cli.ICLIService
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
FetchResults(TFetchResultsReq, AsyncMethodCallback<TCLIService.AsyncClient.FetchResults_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
FetchResults(TFetchResultsReq, AsyncMethodCallback<TCLIService.AsyncClient.FetchResults_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
FetchResults(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
FetchResults(TFetchResultsReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
FetchResults(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
fetchResults(OperationHandle, FetchOrientation, long, FetchType) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
fetchResults(OperationHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
fetchStarted - Variable in class org.apache.hadoop.hive.common.io.FetchConverter
 
fetchStarted() - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
FetchTask - Class in org.apache.hadoop.hive.ql.exec
FetchTask implementation.
FetchTask() - Constructor for class org.apache.hadoop.hive.ql.exec.FetchTask
 
fetchTask - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
fetchTask - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
fetchTransactionBatch(int, RecordWriter) - Method in interface org.apache.hive.hcatalog.streaming.StreamingConnection
Acquires a new batch of transactions from Hive.
FetchType - Enum in org.apache.hive.service.cli
FetchType indicates the type of fetchResults request.
fetchUrl(URL) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
GET the given url.
fetchWaitTime - Variable in class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
Time tasks spent waiting for remote shuffle blocks.
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>>, StructObjectInspector) - 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 - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
Field() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
field - Variable in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
FIELD_DELIM - Static variable in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
FIELD_DELIM - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
FIELD_TO_DIMENSION - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
fieldComment - Variable in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
fieldComment - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TRow
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
fieldForId(int) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
fieldID - Variable in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
fieldid - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
fieldID - Variable in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
fieldID - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
fieldLength - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
FieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
fieldName - Variable in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
fieldName - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
FIELDNAMES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
fieldObjectInspector - Variable in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
fieldObjectInspector - Variable in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
fieldObjectInspector - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
fieldOI - Variable in enum org.apache.hadoop.hive.ql.io.RecordIdentifier.Field
 
FieldRequiredness() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
fields - Variable in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
 
fields - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StructTreeReader
 
fields - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.UnionTreeReader
 
fields - Variable in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
fields - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
fields - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
fields - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For a single column, a split on the secondary separator.
FieldSchema - Class in org.apache.hadoop.hive.metastore.api
 
FieldSchema() - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
 
FieldSchema(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
 
FieldSchema(FieldSchema) - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
Performs a deep copy on other.
FieldSchema._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
fieldsPresent - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
fieldStart - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
fieldsTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
fieldsTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
fieldsTerminatedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
fieldType - Variable in enum org.apache.hadoop.hive.ql.io.RecordIdentifier.Field
 
FieldType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FieldValue() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FILE_INPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
FILE_OUTPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
FileDump - Class in org.apache.hadoop.hive.ql.io.orc
A tool for printing out the file structure of ORC files.
fileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fileFormat(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
fileFormat(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
 
fileFormat() - Method in class org.apache.hive.hcatalog.api.HCatTable
 
FileMergeDesc - Class in org.apache.hadoop.hive.ql.plan
 
FileMergeDesc(DynamicPartitionCtx, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
fileName - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-f option if any that the session has been invoked with.
FILENAME - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
FILES - Static variable in class org.apache.hive.hcatalog.templeton.TempletonDelegator
http://hadoop.apache.org/docs/current/hadoop-project-dist/hadoop-common/CommandsManual.html#Generic_Options
filesCreated - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
fileSinkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counters.
FileSinkOperator.FSPaths - Class in org.apache.hadoop.hive.ql.exec
 
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 is a simple rule to remember seen file sinks for later processing.
FileSinkProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.FileSinkProcessor
 
fileSinkSet - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
fileSinkSet - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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.
fileSystem - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
FileUtils - Class in org.apache.hadoop.hive.common
Collection of file manipulation utilities common across Hive.
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
 
fill(int, Object[]) - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
FillBuff() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
fillColumnStatisticsData(String, ColumnStatisticsData, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
fillColumnStatisticsData(String, ColumnStatisticsData, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, boolean) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
fillDefaultStorageFormat(boolean) - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
fillStorageFormat(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
Returns true if the passed token was a storage format token and thus was processed accordingly.
filter(Text, List<Key>, List<Value>) - Method in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
filter() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FILTER_EXPR_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FILTER_OBJECT_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FILTER_ON_JOIN - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule
 
FILTER_PREFIX - Static variable in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
FILTER_TEXT_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FilterCharColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterCharColumnBetween(int, HiveChar, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
FilterCharColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
FilterCharColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterCharColumnNotBetween(int, HiveChar, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
FilterCharColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
FilterCharScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterCharScalarEqualStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarEqualStringGroupColumn
 
FilterCharScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarEqualStringGroupColumn
 
FilterCharScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterCharScalarGreaterEqualStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterEqualStringGroupColumn
 
FilterCharScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterEqualStringGroupColumn
 
FilterCharScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterCharScalarGreaterStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterStringGroupColumn
 
FilterCharScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterStringGroupColumn
 
FilterCharScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterCharScalarLessEqualStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessEqualStringGroupColumn
 
FilterCharScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessEqualStringGroupColumn
 
FilterCharScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterCharScalarLessStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessStringGroupColumn
 
FilterCharScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessStringGroupColumn
 
FilterCharScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterCharScalarNotEqualStringGroupColumn(HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarNotEqualStringGroupColumn
 
FilterCharScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarNotEqualStringGroupColumn
 
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
 
filterDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
filter to given database object if applicable
filterDatabases(List<String>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterDatabases(List<String>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of databases
filterDatabases(List<String>) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.AuthorizationMetaStoreFilterHook
 
FilterDateColEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColEqualDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColEqualDateScalar
 
FilterDateColEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColEqualDateScalar
 
FilterDateColGreaterDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColGreaterDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterDateScalar
 
FilterDateColGreaterDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterDateScalar
 
FilterDateColGreaterEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColGreaterEqualDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterEqualDateScalar
 
FilterDateColGreaterEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterEqualDateScalar
 
FilterDateColLessDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColLessDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessDateScalar
 
FilterDateColLessDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessDateScalar
 
FilterDateColLessEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColLessEqualDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessEqualDateScalar
 
FilterDateColLessEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessEqualDateScalar
 
FilterDateColNotEqualDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterDateColNotEqualDateScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColNotEqualDateScalar
 
FilterDateColNotEqualDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColNotEqualDateScalar
 
FilterDateScalarEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarEqualDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarEqualDateColumn
 
FilterDateScalarEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarEqualDateColumn
 
FilterDateScalarGreaterDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarGreaterDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterDateColumn
 
FilterDateScalarGreaterDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterDateColumn
 
FilterDateScalarGreaterEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarGreaterEqualDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterEqualDateColumn
 
FilterDateScalarGreaterEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterEqualDateColumn
 
FilterDateScalarLessDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarLessDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessDateColumn
 
FilterDateScalarLessDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessDateColumn
 
FilterDateScalarLessEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarLessEqualDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessEqualDateColumn
 
FilterDateScalarLessEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessEqualDateColumn
 
FilterDateScalarNotEqualDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterDateScalarNotEqualDateColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarNotEqualDateColumn
 
FilterDateScalarNotEqualDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarNotEqualDateColumn
 
FilterDecimalColEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColEqualDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
FilterDecimalColEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
FilterDecimalColEqualDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of decimal values.
FilterDecimalColEqualDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
FilterDecimalColEqualDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
FilterDecimalColGreaterDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColGreaterDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
FilterDecimalColGreaterDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
FilterDecimalColGreaterDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of decimal values.
FilterDecimalColGreaterDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
FilterDecimalColGreaterDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
FilterDecimalColGreaterEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColGreaterEqualDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
FilterDecimalColGreaterEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
FilterDecimalColGreaterEqualDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of decimal values.
FilterDecimalColGreaterEqualDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
FilterDecimalColGreaterEqualDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
FilterDecimalColLessDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColLessDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
FilterDecimalColLessDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
FilterDecimalColLessDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of decimal values.
FilterDecimalColLessDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
FilterDecimalColLessDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
FilterDecimalColLessEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColLessEqualDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
FilterDecimalColLessEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
FilterDecimalColLessEqualDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of decimal values.
FilterDecimalColLessEqualDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
FilterDecimalColLessEqualDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
FilterDecimalColNotEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnCompareColumn.txt, which covers binary comparison filter expressions between two columns.
FilterDecimalColNotEqualDecimalColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
FilterDecimalColNotEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
FilterDecimalColNotEqualDecimalScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of decimal values.
FilterDecimalColNotEqualDecimalScalar(int, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
FilterDecimalColNotEqualDecimalScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
FilterDecimalColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterDecimalColumnBetween(int, HiveDecimal, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
FilterDecimalColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
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.
FilterDecimalColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDecimalColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterDecimalColumnNotBetween(int, HiveDecimal, HiveDecimal) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
FilterDecimalColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
FilterDecimalScalarEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of decimal values.
FilterDecimalScalarEqualDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
FilterDecimalScalarEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
FilterDecimalScalarGreaterDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of decimal values.
FilterDecimalScalarGreaterDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
FilterDecimalScalarGreaterDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
FilterDecimalScalarGreaterEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of decimal values.
FilterDecimalScalarGreaterEqualDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
FilterDecimalScalarGreaterEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
FilterDecimalScalarLessDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of decimal values.
FilterDecimalScalarLessDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
FilterDecimalScalarLessDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
FilterDecimalScalarLessEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of decimal values.
FilterDecimalScalarLessEqualDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
FilterDecimalScalarLessEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
FilterDecimalScalarNotEqualDecimalColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of decimal values.
FilterDecimalScalarNotEqualDecimalColumn(HiveDecimal, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
FilterDecimalScalarNotEqualDecimalColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
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
 
FilterDoubleColEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
FilterDoubleColEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
FilterDoubleColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
FilterDoubleColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
FilterDoubleColEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
FilterDoubleColEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
FilterDoubleColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
FilterDoubleColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
FilterDoubleColGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColGreaterDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
FilterDoubleColGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
FilterDoubleColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColGreaterDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
FilterDoubleColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
FilterDoubleColGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColGreaterEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
FilterDoubleColGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
FilterDoubleColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColGreaterEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
FilterDoubleColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
FilterDoubleColGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColGreaterEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
FilterDoubleColGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
FilterDoubleColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColGreaterEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
FilterDoubleColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
FilterDoubleColGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColGreaterLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
FilterDoubleColGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
FilterDoubleColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColGreaterLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
FilterDoubleColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
FilterDoubleColLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColLessDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
FilterDoubleColLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
FilterDoubleColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColLessDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
FilterDoubleColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
FilterDoubleColLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColLessEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
FilterDoubleColLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
FilterDoubleColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColLessEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
FilterDoubleColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
FilterDoubleColLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColLessEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
FilterDoubleColLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
FilterDoubleColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColLessEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
FilterDoubleColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
FilterDoubleColLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColLessLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
FilterDoubleColLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
FilterDoubleColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColLessLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
FilterDoubleColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
FilterDoubleColNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColNotEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
FilterDoubleColNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
FilterDoubleColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColNotEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
FilterDoubleColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
FilterDoubleColNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterDoubleColNotEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
FilterDoubleColNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
FilterDoubleColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterDoubleColNotEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
FilterDoubleColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
FilterDoubleColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterDoubleColumnBetween(int, double, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
FilterDoubleColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
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.
FilterDoubleColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterDoubleColumnNotBetween(int, double, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
FilterDoubleColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
FilterDoubleScalarEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarEqualDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
FilterDoubleScalarEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
FilterDoubleScalarEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarEqualLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
FilterDoubleScalarEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
FilterDoubleScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarEqualTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualTimestampColumn
 
FilterDoubleScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualTimestampColumn
 
FilterDoubleScalarGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
FilterDoubleScalarGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
FilterDoubleScalarGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterEqualDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
FilterDoubleScalarGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
FilterDoubleScalarGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterEqualLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
FilterDoubleScalarGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
FilterDoubleScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterEqualTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualTimestampColumn
 
FilterDoubleScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualTimestampColumn
 
FilterDoubleScalarGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
FilterDoubleScalarGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
FilterDoubleScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarGreaterTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterTimestampColumn
 
FilterDoubleScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterTimestampColumn
 
FilterDoubleScalarLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
FilterDoubleScalarLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
FilterDoubleScalarLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessEqualDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
FilterDoubleScalarLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
FilterDoubleScalarLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessEqualLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
FilterDoubleScalarLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
FilterDoubleScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessEqualTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualTimestampColumn
 
FilterDoubleScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualTimestampColumn
 
FilterDoubleScalarLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
FilterDoubleScalarLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
FilterDoubleScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarLessTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessTimestampColumn
 
FilterDoubleScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessTimestampColumn
 
FilterDoubleScalarNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarNotEqualDoubleColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
FilterDoubleScalarNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
FilterDoubleScalarNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarNotEqualLongColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
FilterDoubleScalarNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
FilterDoubleScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterDoubleScalarNotEqualTimestampColumn(double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualTimestampColumn
 
FilterDoubleScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualTimestampColumn
 
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
 
filterIndex(Index) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterIndex(Index) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
 
filterIndexes(List<Index>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterIndexes(List<Index>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of index objects
filterIndexNames(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterIndexNames(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of index names
FilterIntervalDayTimeColEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColEqualIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColGreaterIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColGreaterIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterIntervalDayTimeScalar
 
FilterIntervalDayTimeColGreaterIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterIntervalDayTimeScalar
 
FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColLessIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColLessIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessIntervalDayTimeScalar
 
FilterIntervalDayTimeColLessIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessIntervalDayTimeScalar
 
FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar
 
FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarLessIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarLessIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarLessIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
FilterIntervalYearMonthColEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColEqualIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColGreaterIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColGreaterIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterIntervalYearMonthScalar
 
FilterIntervalYearMonthColGreaterIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterIntervalYearMonthScalar
 
FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColLessIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColLessIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessIntervalYearMonthScalar
 
FilterIntervalYearMonthColLessIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessIntervalYearMonthScalar
 
FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar
 
FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarLessIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarLessIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarLessIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterDTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type, however output is not produced in a separate column.
FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
FilterLexer - Class in org.apache.hadoop.hive.metastore.parser
 
FilterLexer() - Constructor for class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
FilterLexer(CharStream) - Constructor for class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
FilterLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizationValidator
see HiveAuthorizer.filterListCmdObjects
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Filter out any objects that should not be shown to the user, from the list of tables or databases coming from a 'show tables' or 'show databases' command
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveV1Authorizer
 
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.DummyHiveAuthorizationValidator
 
filterListCmdObjects(List<HivePrivilegeObject>, HiveAuthzContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizationValidator
 
FilterLongColEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
FilterLongColEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
FilterLongColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
FilterLongColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
FilterLongColEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
FilterLongColEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
FilterLongColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
FilterLongColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
FilterLongColGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColGreaterDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
FilterLongColGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
FilterLongColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColGreaterDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
FilterLongColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
FilterLongColGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColGreaterEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
FilterLongColGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
FilterLongColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColGreaterEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
FilterLongColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
FilterLongColGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColGreaterEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
FilterLongColGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
FilterLongColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColGreaterEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
FilterLongColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
FilterLongColGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColGreaterLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
FilterLongColGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
FilterLongColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColGreaterLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
FilterLongColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
FilterLongColLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColLessDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
FilterLongColLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
FilterLongColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColLessDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
FilterLongColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
FilterLongColLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColLessEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
FilterLongColLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
FilterLongColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColLessEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
FilterLongColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
FilterLongColLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColLessEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
FilterLongColLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
FilterLongColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColLessEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
FilterLongColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
FilterLongColLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColLessLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
FilterLongColLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
FilterLongColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColLessLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
FilterLongColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
FilterLongColNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColNotEqualDoubleColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
FilterLongColNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
FilterLongColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColNotEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
FilterLongColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
FilterLongColNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareColumn.txt, which covers binary comparison expressions between two columns, however output is not produced in a separate column.
FilterLongColNotEqualLongColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
FilterLongColNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
FilterLongColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar, however output is not produced in a separate column.
FilterLongColNotEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
FilterLongColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
FilterLongColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterLongColumnBetween(int, long, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
FilterLongColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
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.
FilterLongColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterColumnBetween.txt, which covers [NOT] BETWEEN filter expressions where a column is [NOT] between one scalar and another.
FilterLongColumnNotBetween(int, long, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
FilterLongColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
FilterLongScalarEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarEqualDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
FilterLongScalarEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
FilterLongScalarEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarEqualLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
FilterLongScalarEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
FilterLongScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualTimestampColumn
 
FilterLongScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualTimestampColumn
 
FilterLongScalarGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
FilterLongScalarGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
FilterLongScalarGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterEqualDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
FilterLongScalarGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
FilterLongScalarGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterEqualLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
FilterLongScalarGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
FilterLongScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualTimestampColumn
 
FilterLongScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualTimestampColumn
 
FilterLongScalarGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
FilterLongScalarGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
FilterLongScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarGreaterTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterTimestampColumn
 
FilterLongScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterTimestampColumn
 
FilterLongScalarLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
FilterLongScalarLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
FilterLongScalarLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessEqualDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
FilterLongScalarLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
FilterLongScalarLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessEqualLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
FilterLongScalarLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
FilterLongScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualTimestampColumn
 
FilterLongScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualTimestampColumn
 
FilterLongScalarLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
FilterLongScalarLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
FilterLongScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarLessTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessTimestampColumn
 
FilterLongScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessTimestampColumn
 
FilterLongScalarNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarNotEqualDoubleColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
FilterLongScalarNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
FilterLongScalarNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareColumn.txt, which covers binary comparison expressions between a scalar and a column, however output is not produced in a separate column.
FilterLongScalarNotEqualLongColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
FilterLongScalarNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
FilterLongScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterScalarCompareTimestampColumn.txt, which covers comparison expressions between a long or double scalar and a column, however output is not produced in a separate column.
FilterLongScalarNotEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualTimestampColumn
 
FilterLongScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualTimestampColumn
 
filterMaps - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
 
FilterParser - Class in org.apache.hadoop.hive.metastore.parser
 
FilterParser(TokenStream) - Constructor for class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FilterParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.hadoop.hive.metastore.parser.FilterParser
 
filterPartition(Partition) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterPartition(Partition) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
filter to given partition object if applicable
filterPartitionNames(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterPartitionNames(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of partition names
filterPartitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterPartitions(List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of partitions
filterPartitionsByExpr(List<String>, List<PrimitiveTypeInfo>, byte[], String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.PartitionExpressionProxy
Filters the partition names via serialized Hive expression.
filterPartitionsByExpr(List<String>, List<PrimitiveTypeInfo>, byte[], String, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore
 
filterPartitionSpecs(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterPartitionSpecs(List<PartitionSpec>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of partition specs
FilterPredicateLeafBuilder - Class in org.apache.hadoop.hive.ql.io.parquet
The base class for building parquet supported filter predicate in primary types.
FilterPredicateLeafBuilder() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.FilterPredicateLeafBuilder
 
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.calcite.stats
 
FilterSelectivityEstimator(RelNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.stats.FilterSelectivityEstimator
 
FilterService - Class in org.apache.hive.service
FilterService.
FilterService(Service) - Constructor for class org.apache.hive.service.FilterService
 
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
 
FilterStringColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterStringColumnBetween(int, byte[], byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
FilterStringColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
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.
FilterStringColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterStringColumnNotBetween(int, byte[], byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
FilterStringColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
FilterStringGroupColEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringGroupColEqualCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualCharScalar
 
FilterStringGroupColEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualCharScalar
 
FilterStringGroupColEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColEqualStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
FilterStringGroupColEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
FilterStringGroupColEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringGroupColEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
FilterStringGroupColEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringGroupColEqualStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringScalar
 
FilterStringGroupColEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringScalar
 
FilterStringGroupColEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringGroupColEqualVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualVarCharScalar
 
FilterStringGroupColEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualVarCharScalar
 
FilterStringGroupColGreaterCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringGroupColGreaterCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterCharScalar
 
FilterStringGroupColGreaterCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterCharScalar
 
FilterStringGroupColGreaterEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringGroupColGreaterEqualCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualCharScalar
 
FilterStringGroupColGreaterEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualCharScalar
 
FilterStringGroupColGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColGreaterEqualStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
FilterStringGroupColGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
FilterStringGroupColGreaterEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringGroupColGreaterEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
FilterStringGroupColGreaterEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringGroupColGreaterEqualStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringScalar
 
FilterStringGroupColGreaterEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringScalar
 
FilterStringGroupColGreaterEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringGroupColGreaterEqualVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualVarCharScalar
 
FilterStringGroupColGreaterEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualVarCharScalar
 
FilterStringGroupColGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColGreaterStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
FilterStringGroupColGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
FilterStringGroupColGreaterStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringGroupColGreaterStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
FilterStringGroupColGreaterStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringGroupColGreaterStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringScalar
 
FilterStringGroupColGreaterStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringScalar
 
FilterStringGroupColGreaterVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringGroupColGreaterVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterVarCharScalar
 
FilterStringGroupColGreaterVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterVarCharScalar
 
FilterStringGroupColLessCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringGroupColLessCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessCharScalar
 
FilterStringGroupColLessCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessCharScalar
 
FilterStringGroupColLessEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringGroupColLessEqualCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualCharScalar
 
FilterStringGroupColLessEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualCharScalar
 
FilterStringGroupColLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColLessEqualStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
FilterStringGroupColLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
FilterStringGroupColLessEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringGroupColLessEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
FilterStringGroupColLessEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringGroupColLessEqualStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringScalar
 
FilterStringGroupColLessEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringScalar
 
FilterStringGroupColLessEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringGroupColLessEqualVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualVarCharScalar
 
FilterStringGroupColLessEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualVarCharScalar
 
FilterStringGroupColLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColLessStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
FilterStringGroupColLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
FilterStringGroupColLessStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringGroupColLessStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
FilterStringGroupColLessStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringGroupColLessStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringScalar
 
FilterStringGroupColLessStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringScalar
 
FilterStringGroupColLessVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringGroupColLessVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessVarCharScalar
 
FilterStringGroupColLessVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessVarCharScalar
 
FilterStringGroupColNotEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringGroupColNotEqualCharScalar(int, HiveChar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualCharScalar
 
FilterStringGroupColNotEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualCharScalar
 
FilterStringGroupColNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
FilterStringGroupColNotEqualStringGroupColumn(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
FilterStringGroupColNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
FilterStringGroupColNotEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringGroupColNotEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
FilterStringGroupColNotEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringGroupColNotEqualStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringScalar
 
FilterStringGroupColNotEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringScalar
 
FilterStringGroupColNotEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringGroupColNotEqualVarCharScalar(int, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualVarCharScalar
 
FilterStringGroupColNotEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualVarCharScalar
 
FilterStringGroupScalarEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringGroupScalarEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
FilterStringGroupScalarGreaterEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringGroupScalarGreaterEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
FilterStringGroupScalarGreaterStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringGroupScalarGreaterStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
FilterStringGroupScalarLessEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringGroupScalarLessEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
FilterStringGroupScalarLessStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringGroupScalarLessStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
FilterStringGroupScalarNotEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringGroupScalarNotEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
FilterStringScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterStringScalarEqualStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarEqualStringGroupColumn
 
FilterStringScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarEqualStringGroupColumn
 
FilterStringScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterStringScalarGreaterEqualStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterEqualStringGroupColumn
 
FilterStringScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterEqualStringGroupColumn
 
FilterStringScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterStringScalarGreaterStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterStringGroupColumn
 
FilterStringScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterStringGroupColumn
 
FilterStringScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterStringScalarLessEqualStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessEqualStringGroupColumn
 
FilterStringScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessEqualStringGroupColumn
 
FilterStringScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterStringScalarLessStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessStringGroupColumn
 
FilterStringScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessStringGroupColumn
 
FilterStringScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterStringScalarNotEqualStringGroupColumn(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarNotEqualStringGroupColumn
 
FilterStringScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarNotEqualStringGroupColumn
 
filterTable(Table) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterTable(Table) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
filter to given table object if applicable
filterTableNames(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterTableNames(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of tables
filterTableNames(String, List<String>) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.AuthorizationMetaStoreFilterHook
 
filterTables(List<Table>) - Method in class org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl
 
filterTables(List<Table>) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFilterHook
Filter given list of tables
filterTags - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
FilterTimestampColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualDoubleScalar
 
FilterTimestampColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualDoubleScalar
 
FilterTimestampColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualLongScalar
 
FilterTimestampColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualLongScalar
 
FilterTimestampColEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColEqualTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualTimestampScalar
 
FilterTimestampColEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualTimestampScalar
 
FilterTimestampColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColGreaterDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterDoubleScalar
 
FilterTimestampColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterDoubleScalar
 
FilterTimestampColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColGreaterEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualDoubleScalar
 
FilterTimestampColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualDoubleScalar
 
FilterTimestampColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColGreaterEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualLongScalar
 
FilterTimestampColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualLongScalar
 
FilterTimestampColGreaterEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColGreaterEqualTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualTimestampScalar
 
FilterTimestampColGreaterEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualTimestampScalar
 
FilterTimestampColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColGreaterLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterLongScalar
 
FilterTimestampColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterLongScalar
 
FilterTimestampColGreaterTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColGreaterTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterTimestampScalar
 
FilterTimestampColGreaterTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterTimestampScalar
 
FilterTimestampColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColLessDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessDoubleScalar
 
FilterTimestampColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessDoubleScalar
 
FilterTimestampColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColLessEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualDoubleScalar
 
FilterTimestampColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualDoubleScalar
 
FilterTimestampColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColLessEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualLongScalar
 
FilterTimestampColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualLongScalar
 
FilterTimestampColLessEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColLessEqualTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualTimestampScalar
 
FilterTimestampColLessEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualTimestampScalar
 
FilterTimestampColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColLessLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessLongScalar
 
FilterTimestampColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessLongScalar
 
FilterTimestampColLessTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColLessTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessTimestampScalar
 
FilterTimestampColLessTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessTimestampScalar
 
FilterTimestampColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColNotEqualDoubleScalar(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualDoubleScalar
 
FilterTimestampColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualDoubleScalar
 
FilterTimestampColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar, however output is not produced in a separate column.
FilterTimestampColNotEqualLongScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualLongScalar
 
FilterTimestampColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualLongScalar
 
FilterTimestampColNotEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar, however output is not produced in a separate column.
FilterTimestampColNotEqualTimestampScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualTimestampScalar
 
FilterTimestampColNotEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualTimestampScalar
 
FilterTimestampScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarEqualTimestampColumn
 
FilterTimestampScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarEqualTimestampColumn
 
FilterTimestampScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarGreaterEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterEqualTimestampColumn
 
FilterTimestampScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterEqualTimestampColumn
 
FilterTimestampScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarGreaterTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterTimestampColumn
 
FilterTimestampScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterTimestampColumn
 
FilterTimestampScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarLessEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessEqualTimestampColumn
 
FilterTimestampScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessEqualTimestampColumn
 
FilterTimestampScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarLessTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessTimestampColumn
 
FilterTimestampScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessTimestampColumn
 
FilterTimestampScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template FilterTimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp scalar and a column, however output is not produced in a separate column.
FilterTimestampScalarNotEqualTimestampColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarNotEqualTimestampColumn
 
FilterTimestampScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarNotEqualTimestampColumn
 
FilterVarCharColumnBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterVarCharColumnBetween(int, HiveVarchar, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
FilterVarCharColumnBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
FilterVarCharColumnNotBetween - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings.
FilterVarCharColumnNotBetween(int, HiveVarchar, HiveVarchar) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
FilterVarCharColumnNotBetween() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
FilterVarCharScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
FilterVarCharScalarEqualStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarEqualStringGroupColumn
 
FilterVarCharScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarEqualStringGroupColumn
 
FilterVarCharScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
FilterVarCharScalarGreaterEqualStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterEqualStringGroupColumn
 
FilterVarCharScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterEqualStringGroupColumn
 
FilterVarCharScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
FilterVarCharScalarGreaterStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterStringGroupColumn
 
FilterVarCharScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterStringGroupColumn
 
FilterVarCharScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
FilterVarCharScalarLessEqualStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessEqualStringGroupColumn
 
FilterVarCharScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessEqualStringGroupColumn
 
FilterVarCharScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
FilterVarCharScalarLessStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessStringGroupColumn
 
FilterVarCharScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessStringGroupColumn
 
FilterVarCharScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
FilterVarCharScalarNotEqualStringGroupColumn(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarNotEqualStringGroupColumn
 
FilterVarCharScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarNotEqualStringGroupColumn
 
finalize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
finalize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOutputMapping
 
finalize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSourceMapping
 
finalize() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
finalize() - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
finalize() - Method in class org.apache.hive.service.server.ThreadWithGarbageCleanup
Add any Thread specific garbage cleanup code here.
finalPath - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
find(String[]) - Static method in enum org.apache.hadoop.hive.ql.processors.HiveCommand
 
find(String[], boolean) - 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
 
findAllSessionItems() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Rather then return the actual items we return a list copies.
findAllSessionsForUser(HWIAuth) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Used to list all the sessions of a user.
findAllUsersWithSessions() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Used to list all users that have at least one session.
findBaseTable(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TRow._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TRow._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TRow._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.EventRequestType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FunctionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockLevel
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.LockType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionEventType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MyEnum
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.service.JobTrackerState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TFetchOrientation
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TOperationState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TOperationType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TProtocolVersion
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TStatusCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hive.service.cli.thrift.TTypeId
Find a the enum type by its integer value, as defined in the Thrift IDL.
findColumn(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
findColumnsWithStats(CompactionInfo) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
Queries metastore DB directly to find columns in the table which have statistics information.
findContainingJar(Class<?>, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Find a jar that contains a class of the same name and which file name matches the given pattern.
findFreePort() - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Finds a free port on the machine.
findLastOperator(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
Starting at the input operator, finds the last operator in the stream that is an instance of the input class.
findLastOperatorUpstream(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
Starting at the input operator, finds the last operator upstream that is an instance of the input class.
findLocalDriver(String) - Method in class org.apache.hive.beeline.BeeLine
 
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
 
findNext(String, char, char, int, StringBuilder) - Static method in class org.apache.hive.common.util.HiveStringUtils
Finds the first occurrence of the separator character ignoring the escaped separators starting from the index.
findNextToCompact(String) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This will grab the next compaction request off of the queue, and assign it to the worker.
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.
findNumCurrentLocks() - Static method in class org.apache.hadoop.hive.metastore.txn.TxnDbUtil
 
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
 
findOperatorsUpstreamJoinAccounted(Operator<?>, Class<T>, Set<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findParents(JoinOperator, Class<T>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
findPossibleParent(Operator<?>, Class<T>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
findPossibleParents(Operator<?>, Class<T>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
findPotentialCompactions(int) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This will look through the completed_txn_components table and look for partitions or tables that may be ready for compaction.
findReadSlot(byte[], int, int, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
findReadSlot(long, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
findReadyToClean() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
Find entries in the queue that are ready to be cleaned.
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.
findSessionItemByName(HWIAuth, String) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Helper method useful when you know the session name you wish to reference.
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
 
findSingleOperatorUpstreamJoinAccounted(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.
findTableScanOperators(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
Search the query plan tree from startPoint to the bottom.
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.
findTopOps(Operator<?>, Class<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
findType(Object) - Static method in class org.apache.hive.hcatalog.data.DataType
Determine the datatype of an object.
finishAdding() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
finished(TaskRunner) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
finished() - Method in class org.apache.hive.testutils.junit.runners.model.ConcurrentScheduler
 
finishedAddingInitialColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
finishInner(VectorizedRowBatch, int, int, int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
Generate the inner join output results for one vectorized row batch.
finishInnerBigOnly(VectorizedRowBatch, int, int, int, VectorMapJoinHashTableResult[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
Generate the inner big table only join output results for one vectorized row batch.
finishInnerBigOnlyRepeated(VectorizedRowBatch, JoinUtil.JoinResult, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
finishInnerRepeated(VectorizedRowBatch, JoinUtil.JoinResult, VectorMapJoinHashTableResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
finishLeftSemi(VectorizedRowBatch, int, int, VectorMapJoinHashTableResult[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
Generate the left semi join output results for one vectorized row batch.
finishLeftSemiRepeated(VectorizedRowBatch, JoinUtil.JoinResult, VectorMapJoinHashTableResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
finishOuter(VectorizedRowBatch, int, int, boolean, boolean, int, int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
Generate the outer join output results for one vectorized row batch.
finishOuterRepeated(VectorizedRowBatch, JoinUtil.JoinResult, VectorMapJoinHashMapResult, boolean, boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
Generate the outer join output results for one vectorized row batch with a repeated key.
finishPartition() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
finishPartition() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
finishRow() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
fire_listener_event(FireEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.fire_listener_event_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
fire_listener_event(FireEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.fire_listener_event_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
fire_listener_event(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
fire_listener_event(FireEventRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
fire_listener_event(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
FireEventRequest - Class in org.apache.hadoop.hive.metastore.api
 
FireEventRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
FireEventRequest(boolean, FireEventRequestData) - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
FireEventRequest(FireEventRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequest
Performs a deep copy on other.
FireEventRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FireEventRequestData - Class in org.apache.hadoop.hive.metastore.api
 
FireEventRequestData() - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
FireEventRequestData(FireEventRequestData._Fields, Object) - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
FireEventRequestData(FireEventRequestData) - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
FireEventRequestData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FireEventResponse - Class in org.apache.hadoop.hive.metastore.api
 
FireEventResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
FireEventResponse(FireEventResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.FireEventResponse
Performs a deep copy on other.
FireEventResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
fireListenerEvent(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
fireListenerEvent(FireEventRequest) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Request that the metastore fire an event.
first() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer.RowIterator
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
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
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
first() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
first() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
first - Variable in class org.apache.hive.hcatalog.data.Pair
 
first() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
firstField - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Is this the first field we're writing.
firstInnerField - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Is this the first list/map/set field we're writing for the current element.
firstItem - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
firstOutputColumnIndex() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
firstSmallTable - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
fitsInt32() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
fixTmpPath(Path, int) - Method in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
Fixes tmpPath to point to the correct partition.
fixTmpPath(Path) - Method in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
fixTopOBSchema(RelNode, Pair<RelNode, RelNode>, List<FieldSchema>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierUtil
 
flag(boolean) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
FLAG_NO_DROP - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FLAG_NO_DROP_CASCADE - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FLAG_OFFLINE - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FLAG_READ_ONLY - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FlagArgs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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
Deprecated.
FlatFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
Deprecated.
 
FlatFileInputFormat.FlatFileRecordReader<R> - Class in org.apache.hadoop.hive.ql.io
Deprecated.
FlatFileInputFormat.FlatFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
Deprecated.
FlatFileRecordReader constructor constructs the underlying stream (potentially decompressed) and creates the deserializer.
FlatFileInputFormat.RowContainer<T> - Class in org.apache.hadoop.hive.ql.io
Deprecated.
A work-around until HADOOP-1230 is fixed.
FlatFileInputFormat.RowContainer() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.RowContainer
Deprecated.
 
FlatFileInputFormat.SerializationContext<S> - Interface in org.apache.hadoop.hive.ql.io
Deprecated.
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
Deprecated.
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
Deprecated.
 
FlatRowContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
 
FlatRowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
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
 
flattenPush() - 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 like comparisons may be affected by appearing order of arguments.
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
 
FLOAT - Static variable in class org.apache.hive.hcatalog.data.DataType
 
FLOAT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
FLOAT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
FLOAT = 5;
FloatObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A FloatObjectInspector inspects an Object representing a Float.
floatTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
floatTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
floatValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Converts this Decimal128 to a float.
floatValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
floatValue() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
floatWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
floatWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
floor(int, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
floor(int, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
flush() - Method in class org.apache.hadoop.hive.common.io.CachingPrintStream
 
flush() - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
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.PTFTopNHash
 
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.
flush() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
flush() - Method in interface org.apache.hive.hcatalog.streaming.RecordWriter
Flush records from buffer.
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.
flushRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
flushToFile() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
flushToFile(MapJoinPersistableTableContainer, byte) - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
flushToFile() - Method in class org.apache.hadoop.hive.ql.exec.TemporaryHashSinkOperator
 
fmt - Variable in class org.apache.hive.common.util.TimestampParser
 
foldExpr(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
FOLLOW_adminOptionFor_in_revokeRole7964 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_aliasList_in_selectTrfmClause324 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_aliasList_in_selectTrfmClause337 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_aliasList_in_trfmClause869 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_aliasList_in_trfmClause882 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_alterDatabaseStatementSuffix_in_alterStatement3821 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterDatabaseSuffixProperties_in_alterDatabaseStatementSuffix4291 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterDatabaseSuffixSetOwner_in_alterDatabaseStatementSuffix4299 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterIndexStatementSuffix_in_alterStatement3801 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectMode_in_alterStatementSuffixProtectMode5891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectModeMode_in_alterProtectMode6080 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectModeMode_in_alterProtectMode6099 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatement_in_ddlStatement1679 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementChangeColPosition_in_alterStatementSuffixRenameCol4615 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementPartitionKeyType_in_alterTableStatementSuffix3934 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddCol_in_alterTblPartitionStatementSuffix4049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddPartitions_in_alterTableStatementSuffix3877 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddPartitions_in_alterViewStatementSuffix4129 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddPartitionsElement_in_alterStatementSuffixAddPartitions4798 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixArchive_in_alterTableStatementSuffix3894 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixBucketNum_in_alterTblPartitionStatementSuffix4013 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixClusterbySortby_in_alterTblPartitionStatementSuffix4025 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixCompact_in_alterTblPartitionStatementSuffix4031 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixDropPartitions_in_alterTableStatementSuffix3868 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixDropPartitions_in_alterViewStatementSuffix4138 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixExchangePartition_in_alterTableStatementSuffix3926 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixFileFormat_in_alterTblPartitionStatementSuffix3977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixLocation_in_alterTblPartitionStatementSuffix3983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixMergeFiles_in_alterTblPartitionStatementSuffix3995 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixProperties_in_alterTableStatementSuffix3910 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixProtectMode_in_alterTblPartitionStatementSuffix3989 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRename_in_alterTableStatementSuffix3859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRename_in_alterViewStatementSuffix4120 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRename_in_synpred3_HiveParser3853 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRenameCol_in_alterTblPartitionStatementSuffix4043 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRenamePart_in_alterTblPartitionStatementSuffix4007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixSerdeProperties_in_alterTblPartitionStatementSuffix4001 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixSkewedby_in_alterTableStatementSuffix3918 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixTouch_in_alterTableStatementSuffix3886 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixUnArchive_in_alterTableStatementSuffix3902 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixUpdateStatsCol_in_alterTblPartitionStatementSuffix4037 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTableStatementSuffix_in_alterStatement3752 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTblPartitionStatementSuffix_in_alterTableStatementSuffix3945 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTblPartitionStatementSuffixSkewedLocation_in_alterTblPartitionStatementSuffix4019 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterViewStatementSuffix_in_alterStatement3779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterViewSuffixProperties_in_alterViewStatementSuffix4112 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_AMPERSAND_in_precedenceAmpersandOperator2517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_analyzeStatement_in_ddlStatement1783 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_andExpression_in_orExpression106 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_andExpression_in_orExpression111 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_atomExpression_in_precedenceFieldExpression2155 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_autoRebuild_in_createIndexStatement3143 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_BETWEEN_in_betweenExpression648 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_betweenExpression_in_operatorExpression206 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_BigintLiteral_in_constant1617 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_binOpExpression_in_operatorExpression218 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_BITWISEOR_in_precedenceBitwiseOrOperator2568 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_BITWISEXOR_in_precedenceBitwiseXorOperator2348 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_body_in_singleFromStatement13623 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_booleanValue_in_constant1657 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_ByteLengthLiteral_in_splitSample1105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_caseExpression_in_atomExpression2087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_castExpression_in_atomExpression2079 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_CharSetLiteral_in_charSetStringLiteral1729 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_CharSetName_in_charSetStringLiteral1725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_charSetStringLiteral_in_constant1649 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_clusterByClause_in_body15033 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_body15185 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_partitioningSpec1591 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_clusterByClause_in_selectStatement13899 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_setOpSelectStatement14554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COLON_in_columnNameColonType12405 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_alterStatementSuffixRenameCol4604 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_colTypeList12525 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_colTypeList12530 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_columnNameColonType12407 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_columnNameType12300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colTypeList_in_unionType13160 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnAssignmentClause_in_setColumnsClause15614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnAssignmentClause_in_setColumnsClause15619 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList11646 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList11651 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonType_in_columnNameColonTypeList11603 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonType_in_columnNameColonTypeList11608 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonTypeList_in_structType13062 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameComment_in_columnNameCommentList12113 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameComment_in_columnNameCommentList12118 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameCommentList_in_createViewStatement9819 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_analyzeStatement6835 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_createIndexStatement3121 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_insertClause15369 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_privlegeDef8730 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_privObjectCols8585 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_tableBuckets10253 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_tableSkewed10338 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_truncateTableStatement3058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_viewPartition9989 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList11722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList11727 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrderList_in_tableBuckets10266 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_alterStatementPartitionKeyType4077 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList11560 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList11565 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_alterStatementSuffixAddCol4511 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_createMacroStatement9690 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_createTableStatement2726 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_selectTrfmClause328 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_columnNameTypeList_in_selectTrfmClause341 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_columnNameTypeList_in_tablePartition10198 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_trfmClause873 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_columnNameTypeList_in_trfmClause886 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_columnRefOrder_in_columnRefOrderInParenthese522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrder_in_columnRefOrderInParenthese527 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrder_in_columnRefOrderNotInParenthese557 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrder_in_columnRefOrderNotInParenthese562 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrder_in_orderByClause609 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrder_in_orderByClause615 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrderInParenthese_in_sortByClause937 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_columnRefOrderNotInParenthese_in_sortByClause957 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_aliasList220 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_alterStatementSuffixDropPartitions5087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_colTypeList12528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameColonTypeList11606 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameCommentList12116 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameList11649 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameOrderList11725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameTypeList11563 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnRefOrderInParenthese525 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_columnRefOrderNotInParenthese560 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_dbPropertiesList2439 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_dropPartitionSpec3511 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_expressionList173 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_expressions3167 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_expressionsInParenthese455 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_expressionsNotInParenthese490 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_function1060 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_grantRole7906 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_groupByClause142 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_groupByClause88 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_groupingSetExpressionMultiple298 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_hintArgs625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_hintList472 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_indexPropertiesList3585 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_joinSource339 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_joinToken552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_lateralView741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_lateralView794 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_mapType13107 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_metastoreCheck9240 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_orderByClause613 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_partitionedTableFunction1729 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_partitionSpec3421 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_COMMA_in_primitiveType12898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_principalSpecification8953 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_privilegeList8679 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_resourceList9298 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_revokeRole7973 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectExpressionList1017 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_selectItem754 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_selectList243 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_setColumnsClause15617 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_skewedColumnValuePairList11811 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_skewedColumnValues11910 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_skewedLocationsList5645 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_synpred2_FromClauseParser737 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_synpred3_FromClauseParser790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_tableBucketSample977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_tableNameColList2055 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_tablePropertiesList10873 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_tablePropertiesList10903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_uniqueJoinExpr410 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_valueRowConstructor1903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_valuesTableConstructor1942 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_COMMA_in_window_clause1063 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_COMMA_in_withClause13329 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_atomExpression2071 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_constant_in_dropPartitionVal3554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_constant_in_partitionVal3465 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_constant_in_skewedColumnValue11956 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_synpred10_IdentifiersParser2066 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_createDatabaseStatement_in_ddlStatement1631 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createFunctionStatement_in_ddlStatement1727 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createIndexStatement_in_ddlStatement1743 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createMacroStatement_in_ddlStatement1735 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createRoleStatement_in_ddlStatement1823 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createTableStatement_in_ddlStatement1655 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createViewStatement_in_ddlStatement1711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_cteStatement_in_withClause13326 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_cteStatement_in_withClause13331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_databaseComment_in_createDatabaseStatement2255 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DateLiteral_in_betweenExpression673 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_DateLiteral_in_betweenExpression681 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_DateLiteral_in_binOpExpression282 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_DateLiteral_in_binOpExpression310 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_dateLiteral_in_constant1577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_dbLocation_in_createDatabaseStatement2266 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbProperties_in_alterDatabaseSuffixProperties4334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbProperties_in_createDatabaseStatement2284 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbPropertiesList_in_dbProperties2393 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ddlStatement_in_execStatement1247 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DecimalLiteral_in_constant1641 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_deleteStatement_in_execStatement1255 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_descFuncNames_in_descStatement6620 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_descStatement_in_ddlStatement1687 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_destination_in_insertClause15334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body15039 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body15191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_partitioningSpec1555 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_distributeByClause_in_selectStatement13907 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_setOpSelectStatement14562 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DIVIDE_in_hintClause420 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_DIVIDE_in_hintClause430 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_DOT_in_functionIdentifier4085 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_DOT_in_precedenceFieldExpression2171 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_DOT_in_tableAllColumns81 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_DOT_in_tableName1331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_DOT_in_tabTypeExpr6403 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_viewName1414 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_dropDatabaseStatement_in_ddlStatement1647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropFunctionStatement_in_ddlStatement1759 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropIndexStatement_in_ddlStatement1751 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropMacroStatement_in_ddlStatement1775 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropPartitionOperator_in_dropPartitionVal3552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_dropPartitionSpec_in_alterStatementSuffixDropPartitions5084 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropPartitionSpec_in_alterStatementSuffixDropPartitions5089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropPartitionVal_in_dropPartitionSpec3508 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_dropPartitionVal_in_dropPartitionSpec3514 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_dropRoleStatement_in_ddlStatement1831 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropTableStatement_in_ddlStatement1663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropViewStatement_in_ddlStatement1719 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement1072 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement1079 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_columnAssignmentClause15589 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_keyValueProperty10953 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_partitionVal3463 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_EQUAL_in_precedenceEqualOperator2653 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_EQUAL_in_skewedLocationMap5695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_NS_in_precedenceEqualOperator2657 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_execStatement_in_explainStatement1112 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_execStatement_in_statement1077 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_explainOption_in_explainStatement1109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_explainStatement_in_statement1070 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_exportStatement_in_execStatement1231 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_andExpression137 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_expression_in_andExpression142 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_expression_in_atomExpression2130 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_caseExpression1419 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_caseExpression1428 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_caseExpression1432 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_caseExpression1443 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_castExpression1346 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_columnRefOrder12213 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_createMacroStatement9695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressionList170 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_expressionList175 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_expressions3164 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_expressions3169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_expressionsInParenthese452 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_expressionsInParenthese457 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_expressionsNotInParenthese487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_expressionsNotInParenthese492 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_groupByClause80 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_groupByClause90 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_groupingExpressionSingle349 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_groupingSetExpressionMultiple294 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_groupingSetExpressionMultiple300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_havingCondition429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_joinSource317 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_partitionedTableFunction1723 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_partitionedTableFunction1735 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_precedenceFieldExpression2162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_searchCondition1871 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_selectExpression983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_expression_in_selectItem728 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_expression_in_synpred10_FromClauseParser1711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_tableBucketSample974 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_tableBucketSample981 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_uniqueJoinExpr407 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_uniqueJoinExpr414 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_expression_in_whenExpression1504 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_whenExpression1508 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expression_in_whenExpression1519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressions_in_precedenceEqualExpression2887 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressions_in_precedenceEqualExpression2970 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsInParenthese_in_clusterByClause681 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsInParenthese_in_distributeByClause852 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsInParenthese_in_partitionByClause767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsNotInParenthese_in_clusterByClause701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsNotInParenthese_in_distributeByClause872 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_expressionsNotInParenthese_in_partitionByClause787 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_fileFormat_in_alterStatementSuffixFileFormat5454 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_selectStatement13859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_simpleSelectStatement14837 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_singleFromStatement13613 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_joinSource303 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_fromSource_in_joinSource310 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_fromSource_in_uniqueJoinSource374 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_fromStatement_in_queryStatementExpressionBody13297 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_function_in_atomExpression2111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_function_in_lateralView726 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_function_in_lateralView779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_functionIdentifier_in_createFunctionStatement9449 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_functionIdentifier_in_descFuncNames3995 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_functionIdentifier_in_dropFunctionStatement9566 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_functionIdentifier_in_functionName1278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_functionIdentifier_in_showFunctionIdentifier10075 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_functionIdentifier_in_synpred8_IdentifiersParser1273 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_functionName_in_function1003 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_functionName_in_synpred11_IdentifiersParser2104 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_grantOptionFor_in_revokePrivileges7841 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_grantPrivileges_in_ddlStatement1845 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_grantPrivileges_in_synpred1_HiveParser1840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_grantRole_in_ddlStatement1899 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_listType13021 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_mapType13113 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_precedenceEqualOperator2677 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_GREATERTHAN_in_structType13064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_unionType13162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHANOREQUALTO_in_precedenceEqualOperator2673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_groupByClause_in_body15015 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_body15167 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_selectStatement13875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_simpleSelectStatement14849 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupingExpressionSingle_in_groupingSetExpression260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_groupingSetExpression_in_groupByClause138 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_groupingSetExpression_in_groupByClause144 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_groupingSetExpressionMultiple_in_groupingSetExpression249 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_havingClause_in_body15021 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_body15173 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_selectStatement13883 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_simpleSelectStatement14855 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingCondition_in_havingClause390 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_hintArgName_in_hintArgs622 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintArgName_in_hintArgs627 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintArgs_in_hintItem517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintClause_in_selectClause73 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintItem_in_hintList469 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintItem_in_hintList474 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintList_in_hintClause426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_hintName_in_hintItem512 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_identifier_in_aliasList217 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_aliasList222 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_alterDatabaseSuffixProperties4328 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterDatabaseSuffixSetOwner4378 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterIndexStatementSuffix4176 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterStatementChangeColPosition4740 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterStatementSuffixRenameCol4598 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterStatementSuffixRenameCol4602 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterStatementSuffixStatsPart5983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_alterStatementSuffixUpdateStatsCol4684 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_betweenExpression638 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression269 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression323 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression371 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression425 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression473 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_Identifier_in_binOpExpression525 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_identifier_in_columnName11695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_columnNameColonType12403 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_columnNameComment12158 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_columnNameOrder12030 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_columnNameType12298 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_createDatabaseStatement2245 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_createIndexStatement3101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createMacroStatement9680 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_createRoleStatement7673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_cteStatement13357 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_descStatement6581 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_dropDatabaseStatement2532 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_dropIndexStatement3634 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropMacroStatement9748 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_dropPartitionVal3550 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_dropRoleStatement7719 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_fileFormat6365 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_functionIdentifier4083 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_functionIdentifier4089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_functionIdentifier4110 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_grantRole7903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_grantRole7908 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_hintArgName669 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_Identifier_in_identifier4016 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_lateralView733 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_lateralView743 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_lateralView786 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_lateralView796 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_lockDatabase7501 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_partitionedTableFunction1673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_partitionedTableFunction1719 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_partitionedTableFunction1731 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_partitionedTableFunction1767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_partitionVal3460 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_precedenceFieldExpression2174 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_principalIdentifier4137 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_identifier_in_principalName9031 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_privObject8461 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_privObject8528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_privObjectCols8559 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_privObjectCols8641 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_revokeRole7970 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_revokeRole7975 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_selectItem741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_identifier_in_selectItem751 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_identifier_in_selectItem756 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_identifier_in_setRole8229 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showRolePrincipals8331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showStatement6940 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showStatement6998 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showStatement7126 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement7233 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showStatement7340 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_showStmtIdentifier10110 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_subQuerySource1478 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_switchDatabaseStatement2482 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_synpred10_FromClauseParser1707 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_synpred12_FromClauseParser1760 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_synpred4_FromClauseParser891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_synpred8_FromClauseParser1260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableAlias850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableFileFormat11472 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_tableName1329 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableName1335 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableName1365 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableNameColList2048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableNameColList2052 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableNameColList2057 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tableOrColumn131 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_tableSource1245 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_tableSource1268 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_tabTypeExpr6400 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_tabTypeExpr6463 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_tabTypeExpr6472 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_unlockDatabase7630 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_identifier_in_viewName1412 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_identifier_in_viewName1420 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Identifier_in_window_defn1101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_Identifier_in_window_specification1141 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_Identifier_in_window_specification1149 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_ifExists_in_alterStatementSuffixDropPartitions5081 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_alterStatementSuffixProperties5215 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_alterViewSuffixProperties5288 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropDatabaseStatement2529 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropFunctionStatement9563 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropIndexStatement3629 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropMacroStatement9745 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropTableStatement3689 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropViewStatement10034 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_alterStatementSuffixAddPartitions4795 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createDatabaseStatement2232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createTableStatement2642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createViewStatement9800 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_insertClause15336 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ignoreProtection_in_alterStatementSuffixDropPartitions5093 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_importStatement_in_execStatement1239 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexComment_in_createIndexStatement3206 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexProperties_in_alterIndexStatementSuffix4240 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexProperties_in_indexPropertiesPrefixed3504 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexPropertiesList_in_indexProperties3539 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexPropertiesPrefixed_in_createIndexStatement3152 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexTblName_in_createIndexStatement3161 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_body14993 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_regularBody13661 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_IntegralLiteral_in_betweenExpression749 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_IntegralLiteral_in_betweenExpression757 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_IntegralLiteral_in_binOpExpression485 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_IntegralLiteral_in_binOpExpression513 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_intervalLiteral_in_constant1593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_intervalQualifiers_in_intervalLiteral1870 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_joinSource_in_fromClause268 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_joinToken_in_joinSource307 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_keyProperty_in_tablePropertiesList10900 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyProperty_in_tablePropertiesList10905 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_dbPropertiesList2436 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_dbPropertiesList2441 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_indexPropertiesList3582 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_indexPropertiesList3587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_tablePropertiesList10870 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_tablePropertiesList10875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddCol4498 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddPartitions4793 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADMIN_in_adminOptionFor9144 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADMIN_in_withAdminOption9183 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AFTER_in_alterStatementChangeColPosition4736 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_privilegeIncludeColObject8378 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_privilegeType8777 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_selectClause79 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ALL_in_setOperator13199 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_setRole8176 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_synpred11_HiveParser8168 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_synpred13_HiveParser8373 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement3746 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement3770 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement3797 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement3813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_privilegeType8791 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ANALYZE_in_analyzeStatement6741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AND_in_andExpression140 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_AND_in_betweenExpression675 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_AND_in_betweenExpression713 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_AND_in_betweenExpression751 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_AND_in_precedenceAndOperator3248 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_AND_in_precedenceEqualExpression3011 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_AND_in_precedenceEqualExpression3064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_AND_in_window_range_expression1238 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_AND_in_window_value_expression1302 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ARCHIVE_in_alterStatementSuffixArchive4938 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ARCHIVE_in_resourceType9407 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ARRAY_in_listType13015 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_alterStatement3776 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_castExpression1358 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_AS_in_createFunctionStatement9451 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createIndexStatement3131 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createTableStatement2838 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createViewStatement9850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_cteStatement13359 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_lateralView731 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_lateralView784 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_selectItem738 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_AS_in_selectItem747 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_AS_in_selectTrfmClause317 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_AS_in_storedAsDirs2087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_subQuerySource1475 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_synpred15_HiveParser11339 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_synpred7_FromClauseParser1235 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_tableFileFormat11348 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat11468 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableNameColList2045 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_tableRowNullFormat11287 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableSource1241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_AS_in_trfmClause862 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_AS_in_window_defn1103 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ASC_in_columnNameOrder12035 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ASC_in_columnRefOrder12218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BETWEEN_in_precedenceEqualExpression3003 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BETWEEN_in_precedenceEqualExpression3056 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BETWEEN_in_window_range_expression1232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_BETWEEN_in_window_value_expression1296 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_BIGINT_in_primitiveType12678 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BINARY_in_primitiveType12866 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BOOLEAN_in_primitiveType12700 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKET_in_tableBucketSample951 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_BUCKETS_in_alterStatementSuffixBucketNum6210 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKETS_in_tableBuckets10278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_clusterByClause663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_distributeByClause834 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_groupByClause74 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_orderByClause607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_partitionByClause749 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_sortByClause919 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_BY_in_tableBuckets10247 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableBuckets10260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableFileFormat11413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tablePartition10194 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatCollItemsIdentifier11123 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier11052 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier11061 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatLinesIdentifier11233 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatMapKeysIdentifier11179 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableSkewed10332 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASCADE_in_alterProtectModeMode6152 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASCADE_in_restrictOrCascade2007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASE_in_caseExpression1417 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CASE_in_whenExpression1493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CAST_in_castExpression1328 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CHANGE_in_alterStatementSuffixRenameCol4591 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CHAR_in_primitiveType12963 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTER_in_clusterByClause661 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CLUSTERED_in_alterStatementSuffixClusterbySortby5487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTERED_in_tableBuckets10245 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLLECTION_in_tableRowFormatCollItemsIdentifier11117 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMN_in_alterStatementPartitionKeyType4073 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMN_in_alterStatementSuffixRenameCol4593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMN_in_alterStatementSuffixStatsPart5978 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMN_in_alterStatementSuffixUpdateStatsCol4679 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_alterStatementSuffixAddCol4507 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_analyzeStatement6830 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_showStatement6979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_truncateTableStatement3054 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_alterStatementSuffixRenameCol4607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_alterStatementSuffixStatsPart5990 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_alterStatementSuffixUpdateStatsCol4691 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameColonType12410 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameComment12161 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameType12303 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_databaseComment2580 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_indexComment3363 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_tableComment10151 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMPACT_in_alterStatementSuffixCompact6250 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMPACTIONS_in_showStatement7372 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMPUTE_in_analyzeStatement6751 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CONCATENATE_in_alterStatementSuffixMergeFiles6041 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CONF_in_showStatement7404 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createDatabaseStatement2216 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createFunctionStatement9438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createIndexStatement3095 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createMacroStatement9674 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createRoleStatement7667 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createTableStatement2624 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createViewStatement9790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_privilegeType8819 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_showStatement7088 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CROSS_in_joinToken587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_CUBE_in_groupByClause114 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CURRENT_DATE_in_dateLiteral1784 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_CURRENT_in_showCurrentRole8113 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CURRENT_in_window_frame_boundary1434 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_CURRENT_in_window_frame_start_boundary1359 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_CURRENT_TIMESTAMP_in_timestampLiteral1835 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DATA_in_loadStatement1292 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_alterStatement3816 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_createDatabaseStatement2219 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_descStatement6570 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_dropDatabaseStatement2524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_lockDatabase7493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_privObject8456 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_privObjectCols8554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_showStatement7225 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_unlockDatabase7622 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASES_in_showStatement6900 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATE_in_dateLiteral1762 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DATE_in_primitiveType12766 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATETIME_in_primitiveType12790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DAY_in_intervalQualifiers1915 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DAY_in_intervalQualifiers1955 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DBPROPERTIES_in_alterDatabaseSuffixProperties4332 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DBPROPERTIES_in_createDatabaseStatement2280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DECIMAL_in_primitiveType12888 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DEFERRED_in_autoRebuild3410 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DEFINED_in_tableRowNullFormat11285 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DELETE_in_deleteStatement15547 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DELETE_in_privilegeType8917 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DELIMITED_in_rowFormatDelimited10649 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnNameOrder12041 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnRefOrder12224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_descStatement6548 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement6546 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORIES_in_storedAsDirs2089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORY_in_destination15431 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISABLE_in_alterProtectMode6097 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTINCT_in_function1052 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DISTINCT_in_selectClause85 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_DISTINCT_in_setOperator13215 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTRIBUTE_in_distributeByClause832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_DOUBLE_in_primitiveType12744 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_alterStatementSuffixDropPartitions5079 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropDatabaseStatement2521 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropFunctionStatement9552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropIndexStatement3625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropMacroStatement9739 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropRoleStatement7713 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropTableStatement3685 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropViewStatement10030 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_privilegeType8833 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELEM_TYPE_in_synpred4_HiveParser6416 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELEM_TYPE_in_tabTypeExpr6421 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELSE_in_caseExpression1441 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ELSE_in_whenExpression1517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ENABLE_in_alterProtectMode6078 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_END_in_caseExpression1451 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_END_in_whenExpression1527 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ESCAPED_in_tableRowFormatFieldIdentifier11059 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXCHANGE_in_alterStatementSuffixExchangePartition5839 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_ifExists1952 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_ifNotExists2048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_precedenceEqualExpression3124 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_EXISTS_in_synpred14_IdentifiersParser3115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_EXPLAIN_in_explainStatement1100 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXPORT_in_exportStatement1438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement6575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement6614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement6663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_showStatement7115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_showStatement7239 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_showStatement7280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTERNAL_in_createTableStatement2636 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTERNAL_in_importStatement1539 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FALSE_in_booleanValue3355 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_FIELDS_in_tableRowFormatFieldIdentifier11048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FILE_in_resourceType9393 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FILEFORMAT_in_alterStatementSuffixFileFormat5452 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FIRST_in_alterStatementChangeColPosition4734 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FLOAT_in_primitiveType12721 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOLLOWING_in_window_frame_boundary1416 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_FOLLOWING_in_window_frame_boundary1460 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_FOR_in_adminOptionFor9148 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOR_in_alterStatementSuffixStatsPart5976 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOR_in_alterStatementSuffixUpdateStatsCol4677 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOR_in_analyzeStatement6828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOR_in_grantOptionFor9111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FOR_in_replicationClause1375 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_rowFormatDelimited10647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_rowFormatSerde10578 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMATTED_in_descStatement6659 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMATTED_in_showStatement7317 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_deleteStatement15549 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_fromClause266 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_FROM_in_importStatement1562 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_revokePrivileges7849 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_revokeRole7979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement6933 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement6982 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement6991 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement7119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement7333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FULL_in_joinToken652 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_FUNCTION_in_createFunctionStatement9447 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_descStatement6612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_dropFunctionStatement9561 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_reloadFunctionStatement9646 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_synpred8_HiveParser6607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTIONS_in_showStatement7026 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_grantOptionFor9107 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_grantPrivileges7759 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_grantRole7898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_showGrants8272 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_showRoleGrants8030 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_withGrantOption9068 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GROUP_in_groupByClause72 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_GROUP_in_principalName9011 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GROUPING_in_groupByClause127 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_HAVING_in_havingClause388 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_HOLD_DDLTIME_in_hintName587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_HOUR_in_intervalQualifiers1967 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IDXPROPERTIES_in_alterIndexStatementSuffix4232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IDXPROPERTIES_in_indexPropertiesPrefixed3501 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IF_in_ifExists1950 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IF_in_ifNotExists2044 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IGNORE_in_ignoreProtection2169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IMPORT_in_importStatement1524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_indexTblName3448 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_precedenceEqualExpression2842 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IN_in_precedenceEqualExpression2885 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IN_in_precedenceEqualExpression2931 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IN_in_precedenceEqualExpression2968 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IN_in_showStatement6935 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement6984 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement6993 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement7121 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement7335 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_synpred12_IdentifiersParser2830 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_IN_in_synpred13_IdentifiersParser2921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_INDEX_in_alterStatement3799 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_createIndexStatement3097 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_dropIndexStatement3627 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_privilegeType8847 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_showStatement7322 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEXES_in_showStatement7324 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INNER_in_joinToken526 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_INPATH_in_loadStatement1301 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTDRIVER_in_fileFormat6314 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTDRIVER_in_tableFileFormat11363 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_fileFormat6295 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_synpred15_HiveParser11341 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_tableFileFormat11350 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INSERT_in_insertClause15330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INSERT_in_insertClause15355 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INSERT_in_privilegeType8903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INT_in_primitiveType12653 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTERVAL_in_intervalLiteral1864 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_INTO_in_alterStatementSuffixBucketNum6204 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_insertClause15357 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_loadStatement1316 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_tableBuckets10272 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IS_in_precedenceUnarySuffixExpression2298 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ITEMS_in_tableRowFormatCollItemsIdentifier11119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JAR_in_resourceType9379 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken589 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken621 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken640 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken660 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_JOIN_in_joinToken676 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_KEY_TYPE_in_synpred5_HiveParser6433 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_KEY_TYPE_in_tabTypeExpr6438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_KEYS_in_tableRowFormatMapKeysIdentifier11175 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LATERAL_in_lateralView720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_LATERAL_in_lateralView775 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_LATERAL_in_synpred1_FromClauseParser711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_LEFT_in_joinToken613 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_LEFT_in_joinToken672 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_LIKE_in_createTableStatement2660 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement6906 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement6945 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement7029 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement7130 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIMIT_in_limitClause15505 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LINES_in_tableRowFormatLinesIdentifier11229 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOAD_in_loadStatement1290 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_destination15427 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_loadStatement1297 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_alterStatementSuffixLocation5738 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_alterTblPartitionStatementSuffixSkewedLocation5552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_dbLocation2345 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_partitionLocation5038 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_tableLocation11520 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCK_in_lockDatabase7490 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCK_in_lockStatement7441 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCK_in_privilegeType8861 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCKS_in_showStatement7199 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MACRO_in_createMacroStatement9678 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MACRO_in_dropMacroStatement9743 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_mapType13099 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_tableRowFormatMapKeysIdentifier11173 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_trfmClause815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_MAPJOIN_in_hintName563 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_METADATA_in_replicationClause1380 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MINUTE_in_intervalQualifiers1979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_MONTH_in_intervalQualifiers1903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_MONTH_in_intervalQualifiers1943 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_MSCK_in_metastoreCheck9222 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NO_DROP_in_alterProtectModeMode6150 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NONE_in_setRole8207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NONE_in_synpred12_HiveParser8199 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOSCAN_in_analyzeStatement6759 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_alterStatementSuffixClusterbySortby5485 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_alterStatementSuffixClusterbySortby5501 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_alterStatementSuffixSkewedby5791 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_alterStatementSuffixSkewedby5806 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_betweenExpression641 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_NOT_in_ifNotExists2046 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_nullCondition2241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_precedenceEqualExpression2756 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_precedenceEqualExpression2840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_precedenceEqualExpression2883 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_precedenceEqualExpression3001 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_precedenceNotOperator3199 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NOT_in_synpred12_IdentifiersParser2828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NULL_in_atomExpression2053 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NULL_in_nullCondition2227 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NULL_in_nullCondition2243 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NULL_in_synpred9_IdentifiersParser2048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_NULL_in_tableRowNullFormat11283 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OF_in_tableBucketSample961 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OFFLINE_in_alterProtectModeMode6135 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_alterIndexStatementSuffix4178 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_createIndexStatement3109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_dropIndexStatement3636 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_joinSource314 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_ON_in_partitionedTableFunction1677 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_ON_in_privilegeObject8427 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_showGrants8278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_showStatement7327 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_tableBucketSample970 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_ON_in_tableSkewed10342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_viewPartition9985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OPTION_in_adminOptionFor9146 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OPTION_in_grantOptionFor9109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OPTION_in_withAdminOption9185 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OPTION_in_withGrantOption9070 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OR_in_orExpression109 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_KW_OR_in_orReplace2126 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OR_in_precedenceOrOperator3299 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ORDER_in_orderByClause605 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_OUT_in_tableBucketSample959 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTER_in_joinToken617 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTER_in_joinToken636 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTER_in_joinToken656 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTER_in_lateralView724 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTER_in_synpred1_FromClauseParser715 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_OUTPUTDRIVER_in_fileFormat6320 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTDRIVER_in_tableFileFormat11369 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTFORMAT_in_fileFormat6301 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTFORMAT_in_tableFileFormat11356 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVER_in_function1083 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_OVERWRITE_in_insertClause15332 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVERWRITE_in_loadStatement1312 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OWNER_in_alterDatabaseSuffixSetOwner4382 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTIALSCAN_in_analyzeStatement6767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITION_in_alterStatementPartitionKeyType4071 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITION_in_dropPartitionSpec3499 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_PARTITION_in_partitionByClause747 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_PARTITION_in_partitionSpec3409 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_PARTITIONED_in_tablePartition10192 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONED_in_viewPartition9983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONS_in_showStatement7058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PERCENT_in_splitSample1048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_PRECEDING_in_window_frame_boundary1412 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_PRECEDING_in_window_frame_boundary1454 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_PRECEDING_in_window_frame_start_boundary1343 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_PRECEDING_in_window_frame_start_boundary1376 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_PRESERVE_in_uniqueJoinSource371 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_PRETTY_in_descStatement6667 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PRINCIPALS_in_showRolePrincipals8327 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PROTECTION_in_ignoreProtection2171 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PURGE_in_alterStatementSuffixDropPartitions5096 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PURGE_in_dropTableStatement3694 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RANGE_in_window_value_expression1276 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_RANGE_in_window_value_expression1294 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_READONLY_in_alterProtectModeMode6170 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REBUILD_in_alterIndexStatementSuffix4197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REBUILD_in_autoRebuild3412 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RECORDREADER_in_recordReader10474 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RECORDWRITER_in_recordWriter10525 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REDUCE_in_trfmClause830 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_RELOAD_in_reloadFunctionStatement9644 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RENAME_in_alterStatementSuffixRename4427 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RENAME_in_alterStatementSuffixRenamePart5930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPAIR_in_metastoreCheck9227 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPLACE_in_alterStatementSuffixAddCol4504 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPLACE_in_orReplace2128 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPLICATION_in_replicationClause1384 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RESTRICT_in_restrictOrCascade1989 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REVOKE_in_revokePrivileges7839 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REVOKE_in_revokeRole7962 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REWRITE_in_explainStatement1143 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RIGHT_in_joinToken633 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_ROLE_in_createRoleStatement7669 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_dropRoleStatement7715 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_grantRole7900 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_principalName9029 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_revokeRole7967 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_setRole8154 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLE_in_showRoleGrants8028 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLES_in_showCurrentRole8115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLES_in_showRoles8074 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROLLUP_in_groupByClause104 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_ROW_in_rowFormatDelimited10645 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_rowFormatSerde10576 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_window_frame_boundary1436 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ROW_in_window_frame_start_boundary1361 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ROWS_in_splitSample1050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_ROWS_in_window_range_expression1212 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_ROWS_in_window_range_expression1230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_SCHEMA_in_alterStatement3818 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_createDatabaseStatement2221 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_descStatement6572 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_dropDatabaseStatement2526 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_lockDatabase7495 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_privObject8458 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_privObjectCols8556 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_showStatement7227 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_unlockDatabase7624 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMAS_in_showStatement6902 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SECOND_in_intervalQualifiers1919 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SECOND_in_intervalQualifiers1991 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SELECT_in_privilegeType8875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SELECT_in_selectClause71 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_SELECT_in_synpred12_IdentifiersParser2834 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SELECT_in_synpred13_IdentifiersParser2925 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SELECT_in_synpred14_IdentifiersParser3119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SEMI_in_joinToken674 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_SERDE_in_alterStatementSuffixSerdeProperties5335 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_fileFormat6307 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_rowFormatSerde10580 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties5344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties5374 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_rowFormatSerde10589 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_tableFileFormat11431 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERVER_in_privObject8526 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERVER_in_privObjectCols8639 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterDatabaseSuffixProperties4330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterDatabaseSuffixSetOwner4380 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterIndexStatementSuffix4230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixFileFormat5450 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixLocation5736 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixProperties5187 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties5333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties5372 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixStatsPart5985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixUpdateStatsCol4686 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterTblPartitionStatementSuffixSkewedLocation5548 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterViewSuffixProperties5260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_setColumnsClause15612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_setRole8152 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SETS_in_groupByClause129 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SHOW_DATABASE_in_privilegeType8889 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showCurrentRole8111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showGrants8270 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showRoleGrants8026 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showRolePrincipals8325 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showRoles8072 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement6897 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement6927 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement6977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7024 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7056 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7086 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7312 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7370 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7386 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement7402 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SKEWED_in_alterStatementSuffixSkewedby5793 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SKEWED_in_alterTblPartitionStatementSuffixSkewedLocation5550 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SKEWED_in_tableSkewed10330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SMALLINT_in_primitiveType12633 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORT_in_sortByClause917 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_SORTED_in_alterStatementSuffixClusterbySortby5503 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORTED_in_tableBuckets10258 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STATISTICS_in_alterStatementSuffixStatsPart5974 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STATISTICS_in_alterStatementSuffixUpdateStatsCol4675 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STATISTICS_in_analyzeStatement6753 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_storedAsDirs2085 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_synpred15_HiveParser11337 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat11346 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat11411 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat11466 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STREAMTABLE_in_hintName575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_STRING_in_primitiveType12844 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STRUCT_in_structType13058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_alterStatement3748 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_alterStatementSuffixExchangePartition5845 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_analyzeStatement6743 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_createIndexStatement3111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_createTableStatement2640 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_destination15471 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_dropTableStatement3687 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_exportStatement1446 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_importStatement1543 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_indexTblName3450 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_insertClause15359 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_loadStatement1318 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_lockStatement7443 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_metastoreCheck9232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_privObject8477 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_privObjectCols8575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_showStatement7090 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_showStatement7113 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_truncateTableStatement3049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_unlockStatement7575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLES_in_showStatement6929 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLESAMPLE_in_splitSample1034 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_TABLESAMPLE_in_splitSample1097 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_TABLESAMPLE_in_tableBucketSample947 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterStatementSuffixProperties5189 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterStatementSuffixProperties5213 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterViewSuffixProperties5262 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterViewSuffixProperties5286 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_showStatement7164 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_tablePropertiesPrefixed10789 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_createFunctionStatement9443 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_createMacroStatement9676 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_createTableStatement2629 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_dropFunctionStatement9557 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_dropMacroStatement9741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatCollItemsIdentifier11121 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatFieldIdentifier11050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatLinesIdentifier11231 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatMapKeysIdentifier11177 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_THEN_in_caseExpression1430 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_THEN_in_whenExpression1506 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_TIMESTAMP_in_primitiveType12810 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TIMESTAMP_in_timestampLiteral1813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_TINYINT_in_primitiveType12612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_alterStatementSuffixRename4429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_alterStatementSuffixRenamePart5932 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_exportStatement1460 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_grantPrivileges7780 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_grantRole7912 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_intervalQualifiers1901 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_TO_in_intervalQualifiers1917 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_TOUCH_in_alterStatementSuffixTouch4891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRANSACTIONS_in_showStatement7388 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRANSFORM_in_selectClause123 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_TRUE_in_booleanValue3350 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_TRUNCATE_in_truncateTableStatement3047 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNARCHIVE_in_alterStatementSuffixUnArchive4985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNBOUNDED_in_window_frame_boundary1407 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_UNBOUNDED_in_window_frame_start_boundary1341 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_UNION_in_setOperator13197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNION_in_setOperator13213 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNIONTYPE_in_unionType13156 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNIQUEJOIN_in_uniqueJoinToken461 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_UNLOCK_in_unlockDatabase7619 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNLOCK_in_unlockStatement7573 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNSET_in_alterStatementSuffixProperties5211 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNSET_in_alterViewSuffixProperties5284 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UPDATE_in_alterStatementSuffixStatsPart5972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UPDATE_in_alterStatementSuffixUpdateStatsCol4673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UPDATE_in_privilegeType8805 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UPDATE_in_updateStatement15661 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_URI_in_privObject8502 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_URI_in_privObjectCols8615 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USE_in_switchDatabaseStatement2480 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USER_in_principalName8993 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USING_in_createFunctionStatement9462 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USING_in_selectTrfmClause307 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_USING_in_trfmClause852 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_VALUE_TYPE_in_synpred6_HiveParser6450 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VALUE_TYPE_in_tabTypeExpr6455 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VALUES_in_valuesClause1978 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_VARCHAR_in_primitiveType12930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_alterStatement3772 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_createViewStatement9797 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_dropViewStatement10032 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_lateralView722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_VIEW_in_lateralView777 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_VIEW_in_synpred1_FromClauseParser713 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_WHEN_in_caseExpression1426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_WHEN_in_whenExpression1502 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_WHERE_in_whereClause1830 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_KW_WINDOW_in_window_clause1058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_KW_WITH_in_alterStatementSuffixExchangePartition5843 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_alterStatementSuffixSerdeProperties5342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_autoRebuild3408 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_createDatabaseStatement2278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_groupByClause102 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_WITH_in_groupByClause112 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_WITH_in_rowFormatSerde10587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_tableFileFormat11429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_withAdminOption9181 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_withClause13324 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_withGrantOption9066 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_YEAR_in_intervalQualifiers1899 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_KW_YEAR_in_intervalQualifiers1931 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_lateralView_in_body15003 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lateralView_in_body15155 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lateralView_in_fromSource913 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LESSTHAN_in_listType13017 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_mapType13101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_precedenceEqualOperator2669 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LESSTHAN_in_structType13060 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_unionType13158 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHANOREQUALTO_in_precedenceEqualOperator2665 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_limitClause_in_body15057 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_body15209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_selectStatement13931 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_setOpSelectStatement14586 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_listType_in_type12566 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_loadStatement_in_execStatement1223 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockDatabase_in_ddlStatement1807 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockMode_in_lockDatabase7504 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockMode_in_lockStatement7450 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockStatement_in_ddlStatement1791 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_alterStatementPartitionKeyType4075 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_alterStatementSuffixAddCol4509 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_atomExpression2127 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_castExpression1334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_columnRefOrderInParenthese520 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_createIndexStatement3117 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createMacroStatement9688 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createTableStatement2724 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createViewStatement9817 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_cteStatement13361 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_dbProperties2391 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_dropPartitionSpec3506 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_expression169 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_LPAREN_in_expressions3162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_expressionsInParenthese450 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_function1009 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_groupByClause136 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_groupingSetExpressionMultiple288 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_hintItem515 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LPAREN_in_indexProperties3537 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_insertClause15365 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_partitionedTableFunction1675 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_partitionedTableFunction1721 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_partitionedTableFunction1733 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_partitionSpec3416 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_primitiveType12891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_primitiveType12932 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_primitiveType12965 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_privlegeDef8726 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_privObjectCols8581 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_replicationClause1386 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_selectItem749 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LPAREN_in_selectTrfmClause285 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LPAREN_in_selectTrfmClause321 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LPAREN_in_showStatement7169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_skewedColumnValuePair11858 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_skewedLocations5597 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_splitSample1036 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_splitSample1099 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_subQueryExpression2700 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_subQuerySource1468 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_synpred10_FromClauseParser1709 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_synpred11_IdentifiersParser2106 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred12_IdentifiersParser2832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred13_IdentifiersParser2923 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred14_IdentifiersParser3117 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred1_IdentifiersParser244 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred2_IdentifiersParser676 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred3_IdentifiersParser762 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred4_FromClauseParser893 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_synpred4_IdentifiersParser847 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_synpred5_IdentifiersParser932 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_LPAREN_in_tableBuckets10249 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBuckets10262 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBucketSample949 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_tableNameColList2050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_tablePartition10196 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableProperties10825 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableSkewed10334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableSkewed10344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_trfmClause866 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LPAREN_in_truncateTableStatement3056 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_uniqueJoinExpr403 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_valueRowConstructor1898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_viewPartition9987 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_virtualTableSource2007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_LPAREN_in_window_specification1147 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_LSQUARE_in_precedenceFieldExpression2159 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_mapType_in_type12582 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_metastoreCheck_in_ddlStatement1703 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_nonReserved_in_identifier4024 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_NOTEQUAL_in_precedenceEqualOperator2661 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_nullCondition_in_precedenceUnarySuffixExpression2300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_Number_in_alterStatementSuffixBucketNum6208 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_constant1569 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_Number_in_limitClause15509 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_primitiveType12895 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_primitiveType12902 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_primitiveType12936 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_primitiveType12969 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_splitSample1042 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Number_in_tableBuckets10276 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableBucketSample956 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Number_in_tableBucketSample966 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_Number_in_window_frame_boundary1449 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_Number_in_window_frame_start_boundary1374 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_operator_in_binOpExpression275 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operator_in_binOpExpression317 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operator_in_binOpExpression377 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operator_in_binOpExpression419 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operator_in_binOpExpression479 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operator_in_binOpExpression519 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_operatorExpression_in_expression185 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_orderByClause_in_body15027 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_body15179 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_partitioningSpec1521 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_orderByClause_in_partitioningSpec1540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_orderByClause_in_selectStatement13891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_setOpSelectStatement14546 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orExpression_in_expression171 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_orExpression_in_filter84 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_orReplace_in_createViewStatement9793 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionByClause_in_partitioningSpec1519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_partitionedTableFunction_in_fromSource897 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_partitionedTableFunction_in_partitionTableFunctionSource1642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_partitioningSpec_in_partitionedTableFunction1697 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_partitioningSpec_in_window_specification1152 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_partitionLocation_in_alterStatementSuffixAddPartitionsElement4863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterIndexStatementSuffix4182 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixAddPartitionsElement4861 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixArchive4941 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixExchangePartition5841 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixRenamePart5934 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixTouch4894 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixUnArchive4988 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterTableStatementSuffix3942 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_lockStatement7447 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck9236 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck9242 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_partTypeExpr6502 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_privObject8482 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_privObjectCols8591 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_showStatement7064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_showStatement7134 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_tableOrPartition3377 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_partitionSpec_in_tablePartitionPrefix5415 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_unlockStatement7579 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionTableFunctionSource_in_partitionedTableFunction1693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_partitionVal_in_partitionSpec3418 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_partitionVal_in_partitionSpec3424 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_partTypeExpr_in_descStatement6672 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partTypeExpr_in_descStatement6699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partTypeExpr_in_showStatement7273 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_PLUS_in_hintClause424 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression2589 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression2595 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceAmpersandOperator_in_precedenceAmpersandExpression2541 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression3320 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression3326 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceAndOperator_in_precedenceAndExpression3272 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression2734 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression2762 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression2799 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression3008 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression3016 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression3061 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression3069 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseOrOperator_in_precedenceBitwiseOrExpression2592 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression2432 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression2438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceBitwiseXorOperator_in_precedenceBitwiseXorExpression2372 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceEqualExpression_in_precedenceNotExpression3226 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceEqualNegatableOperator_in_precedenceEqualExpression2758 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceEqualNegatableOperator_in_precedenceEqualOperator2649 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceEqualOperator_in_precedenceEqualExpression2795 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceFieldExpression_in_precedenceUnaryPrefixExpression2276 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression3269 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression3275 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceNotOperator_in_precedenceNotExpression3221 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceOrExpression_in_expression2026 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceOrOperator_in_precedenceOrExpression3323 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedencePlusExpression_in_columnAssignmentClause15592 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression2538 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression2544 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedencePlusOperator_in_precedencePlusExpression2490 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression2487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression2493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceStarOperator_in_precedenceStarExpression2435 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceUnaryOperator_in_precedenceUnaryPrefixExpression2271 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceUnaryPrefixExpression_in_precedenceUnarySuffixExpression2293 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceUnaryPrefixExpression_in_valueRowConstructor1900 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_precedenceUnaryPrefixExpression_in_valueRowConstructor1905 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression2369 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression2375 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_primitiveType_in_castExpression1370 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_primitiveType_in_mapType13105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_type12558 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalIdentifier_in_principalName8995 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalIdentifier_in_principalName9013 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_alterDatabaseSuffixSetOwner4384 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_principalSpecification8950 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_principalSpecification8955 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_showGrants8274 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_showRoleGrants8032 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_grantPrivileges7782 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_grantRole7914 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_revokePrivileges7851 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_revokeRole7981 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeIncludeColObject_in_showGrants8280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeList_in_grantPrivileges7763 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeList_in_revokePrivileges7844 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeObject_in_grantPrivileges7771 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeObject_in_revokePrivileges7846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeType_in_privlegeDef8723 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privlegeDef_in_privilegeList8676 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privlegeDef_in_privilegeList8681 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privObject_in_privilegeObject8429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privObjectCols_in_privilegeIncludeColObject8392 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_cteStatement13363 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_execStatement1214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_explainStatement1145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_subQuerySource1470 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_queryStatementExpressionBody_in_queryStatementExpression13263 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_QuotedIdentifier_in_principalIdentifier4145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_recordReader_in_selectTrfmClause357 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_recordReader_in_trfmClause902 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_recordWriter_in_selectTrfmClause301 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_recordWriter_in_trfmClause846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_regularBody_in_queryStatementExpressionBody13306 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_reloadFunctionStatement_in_ddlStatement1767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_replicationClause_in_alterStatementSuffixDropPartitions5099 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_replicationClause_in_dropTableStatement3697 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_replicationClause_in_exportStatement1474 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_resource_in_resourceList9295 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_resource_in_resourceList9300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_resourceList_in_createFunctionStatement9466 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_resourceType_in_resource9338 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_restrictOrCascade_in_alterStatementSuffixAddCol4515 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_restrictOrCascade_in_alterStatementSuffixRenameCol4618 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_restrictOrCascade_in_dropDatabaseStatement2534 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_revokePrivileges_in_ddlStatement1859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_revokePrivileges_in_synpred2_HiveParser1854 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_revokeRole_in_ddlStatement1907 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormat_in_selectTrfmClause297 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_rowFormat_in_selectTrfmClause353 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_rowFormat_in_trfmClause842 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_rowFormat_in_trfmClause898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_rowFormatDelimited_in_rowFormat10425 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatDelimited_in_tableRowFormat10722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatSerde_in_rowFormat10409 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatSerde_in_tableRowFormat10742 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_alterStatementPartitionKeyType4079 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_alterStatementSuffixAddCol4513 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_atomExpression2132 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_castExpression1376 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_columnRefOrderInParenthese531 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_createIndexStatement3123 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createMacroStatement9693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createTableStatement2728 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createViewStatement9821 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_cteStatement13366 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_dbProperties2395 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_dropPartitionSpec3519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_expression173 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_RPAREN_in_expressions3173 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_expressionsInParenthese461 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_function1080 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_groupByClause149 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_groupingSetExpressionMultiple307 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_hintItem519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RPAREN_in_indexProperties3541 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_insertClause15371 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_partitionedTableFunction1725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_partitionedTableFunction1737 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_partitionedTableFunction1754 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_partitionSpec3429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_primitiveType12906 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_primitiveType12938 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_primitiveType12971 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_privlegeDef8732 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_privObjectCols8587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_replicationClause1394 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_selectItem760 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RPAREN_in_selectTrfmClause289 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RPAREN_in_selectTrfmClause331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RPAREN_in_showStatement7175 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_skewedColumnValuePair11864 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_skewedLocations5601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_splitSample1053 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_splitSample1108 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_subQueryExpression2706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_RPAREN_in_subQuerySource1473 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_synpred10_FromClauseParser1713 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_tableBuckets10255 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBuckets10268 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBucketSample987 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_tableNameColList2061 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_tablePartition10200 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableProperties10829 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableSkewed10340 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableSkewed10352 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_trfmClause876 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RPAREN_in_truncateTableStatement3060 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_uniqueJoinExpr418 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_valueRowConstructor1909 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_viewPartition9991 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_virtualTableSource2011 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_RPAREN_in_window_specification1158 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_RSQUARE_in_precedenceFieldExpression2164 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_searchCondition_in_whereClause1832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_selectClause_in_body14998 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_body15150 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_selectStatement13852 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_simpleSelectStatement14832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_function1057 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_selectExpression_in_function1062 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_selectExpression_in_selectExpressionList1014 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectExpression_in_selectExpressionList1019 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectExpressionList_in_selectTrfmClause287 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectExpressionList_in_trfmClause820 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectExpressionList_in_trfmClause832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectItem_in_selectList239 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectItem_in_selectList246 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectList_in_selectClause89 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_selectStatement_in_regularBody13673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_regularBody13825 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_selectStatementWithCTE14962 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_subQueryExpression2703 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_selectStatementWithCTE_in_alterViewStatementSuffix4147 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatementWithCTE_in_createTableStatement2840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatementWithCTE_in_createViewStatement9860 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectTrfmClause_in_selectClause125 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_set_in_functionName1241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_set_in_operator573 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_setColumnsClause_in_updateStatement15665 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_setOperator_in_fromStatement13402 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_setOperator_in_setOpSelectStatement14115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_setOpSelectStatement_in_selectStatement14053 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_setRole_in_ddlStatement1915 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showCurrentRole_in_ddlStatement1923 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showFunctionIdentifier_in_showStatement7031 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showFunctionIdentifier_in_showStatement7033 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showGrants_in_ddlStatement1867 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showRoleGrants_in_ddlStatement1875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showRolePrincipals_in_ddlStatement1883 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showRoles_in_ddlStatement1891 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStatement_in_ddlStatement1695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement6908 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement6947 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement6949 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement7132 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement7329 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_simpleSelectStatement_in_setOpSelectStatement14119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_singleFromStatement_in_fromStatement13390 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_singleFromStatement_in_fromStatement13406 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValue_in_skewedColumnValues11907 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValue_in_skewedColumnValues11912 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValue_in_skewedValueLocationElement11990 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValuePair_in_skewedColumnValuePairList11808 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValuePair_in_skewedColumnValuePairList11813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValuePair_in_skewedValueLocationElement11999 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValuePairList_in_skewedValueElement11781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValues_in_skewedColumnValuePair11862 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedColumnValues_in_skewedValueElement11772 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedLocationMap_in_skewedLocationsList5642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedLocationMap_in_skewedLocationsList5647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedLocations_in_alterTblPartitionStatementSuffixSkewedLocation5554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedLocationsList_in_skewedLocations5599 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedValueElement_in_tableSkewed10349 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_skewedValueLocationElement_in_skewedLocationMap5693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_SmallintLiteral_in_constant1625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_sortByClause_in_body15045 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_body15197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_partitioningSpec1557 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_sortByClause_in_partitioningSpec1576 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_sortByClause_in_selectStatement13915 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_setOpSelectStatement14570 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_splitSample_in_tableSample1162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_sql11ReservedKeywordsUsedAsCastFunctionName_in_functionName1292 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_sql11ReservedKeywordsUsedAsIdentifier_in_identifier4049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_STAR_in_function1036 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_STAR_in_hintClause422 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_STAR_in_hintClause428 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_STAR_in_synpred6_IdentifiersParser1028 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_STAR_in_tableAllColumns57 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_STAR_in_tableAllColumns83 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_storedAsDirs_in_alterStatementSuffixSkewedby5808 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_storedAsDirs_in_synpred14_HiveParser10356 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_storedAsDirs_in_tableSkewed10361 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixCompact6254 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixLocation5742 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixRenameCol4611 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixSerdeProperties5339 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixStatsPart5994 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixUpdateStatsCol4695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_betweenExpression711 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_StringLiteral_in_betweenExpression719 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_StringLiteral_in_binOpExpression384 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_StringLiteral_in_binOpExpression412 - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
FOLLOW_StringLiteral_in_columnNameColonType12414 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameComment12165 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameType12307 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_constant1601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_createFunctionStatement9453 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_createIndexStatement3135 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_databaseComment2584 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_dateLiteral1764 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_dbLocation2349 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_descFuncNames3987 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_destination15433 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_exportStatement1465 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat6299 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat6305 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat6311 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat6318 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat6324 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_importStatement1567 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_indexComment3367 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_intervalLiteral1866 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_keyProperty11004 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty10951 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty10957 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_loadStatement1306 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_partitionLocation5042 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_privObject8507 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_privObjectCols8620 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_recordReader10476 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_recordWriter10527 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_replicationClause1391 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_resource9342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_rowFormatSerde10584 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_selectTrfmClause309 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_StringLiteral_in_showFunctionIdentifier10083 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_showStatement7173 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_showStatement7406 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_showStmtIdentifier10118 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_skewedLocationMap5699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_stringLiteralSequence1678 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_stringLiteralSequence1680 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_tableComment10155 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat11354 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat11360 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat11367 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat11373 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat11417 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableLocation11524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatCollItemsIdentifier11127 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier11056 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier11065 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatLinesIdentifier11237 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatMapKeysIdentifier11183 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowNullFormat11291 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_timestampLiteral1815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_StringLiteral_in_trfmClause854 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_stringLiteralSequence_in_constant1609 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_structType_in_type12574 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_subQueryExpression_in_precedenceEqualExpression2844 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_subQueryExpression_in_precedenceEqualExpression2933 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_subQueryExpression_in_precedenceEqualExpression3126 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_subQuerySource_in_fromSource905 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_subQuerySource_in_partitionTableFunctionSource1628 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_switchDatabaseStatement_in_ddlStatement1639 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sysFuncNames_in_descFuncNames3979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_sysFuncNames_in_synpred15_IdentifiersParser3974 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_tableAlias_in_lateralView728 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableAlias_in_lateralView781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableAllColumns_in_selectExpression971 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_tableAllColumns_in_selectItem706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_tableAllColumns_in_synpred1_SelectClauseParser701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_tableAllColumns_in_synpred2_SelectClauseParser966 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_tableBuckets_in_alterStatementSuffixClusterbySortby5517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableBuckets_in_createTableStatement2765 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableBucketSample_in_tableSample1154 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableComment_in_createTableStatement2741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableComment_in_createViewStatement9825 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createIndexStatement3179 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createTableStatement2687 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createTableStatement2801 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_destination15438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createIndexStatement3188 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createTableStatement2699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createTableStatement2813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_importStatement1579 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_alterIndexStatementSuffix4180 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_alterStatement3750 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_alterStatement3774 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_alterStatementSuffixExchangePartition5849 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_alterStatementSuffixRename4431 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createIndexStatement3115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createTableStatement2647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createTableStatement2664 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createViewStatement9806 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_deleteStatement15551 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_dropIndexStatement3640 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_dropTableStatement3692 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_indexTblName3454 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_lockStatement7445 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_metastoreCheck9234 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_privObject8480 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_privObjectCols8578 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_showStatement6987 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_showStatement7062 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_showStatement7094 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_showStatement7166 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_tableAllColumns79 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableName_in_tableOrPartition3375 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_tableName_in_tablePartitionPrefix5413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_tableSource1191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableName_in_unlockStatement7577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_updateStatement15663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableNameColList_in_virtualTableSource2013 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableOrColumn_in_atomExpression2119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_tableOrColumn_in_columnAssignmentClause15587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_analyzeStatement6748 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_destination15473 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_exportStatement1451 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_importStatement1548 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_insertClause15362 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_loadStatement1323 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePartition_in_createTableStatement2753 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePartitionPrefix_in_truncateTableStatement3051 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixProperties5191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixProperties5218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties5346 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties5376 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixStatsPart5987 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixUpdateStatsCol4688 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterViewSuffixProperties5264 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterViewSuffixProperties5291 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_rowFormatSerde10593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_synpred5_FromClauseParser1200 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableProperties_in_tableFileFormat11435 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_tablePropertiesPrefixed10792 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_tableSource1207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tablePropertiesList_in_tableProperties10827 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createIndexStatement3197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createTableStatement2711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createTableStatement2825 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createViewStatement9839 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createIndexStatement3170 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createTableStatement2675 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createTableStatement2789 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_destination15435 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatCollItemsIdentifier_in_rowFormatDelimited10654 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatFieldIdentifier_in_rowFormatDelimited10651 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatLinesIdentifier_in_rowFormatDelimited10660 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatMapKeysIdentifier_in_rowFormatDelimited10657 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowNullFormat_in_rowFormatDelimited10663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSample_in_synpred6_FromClauseParser1217 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableSample_in_tableSource1224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableSkewed_in_alterStatementSuffixSkewedby5776 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSkewed_in_createTableStatement2777 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSource_in_fromSource901 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tableSource_in_partitionTableFunctionSource1635 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_tabTypeExpr_in_partTypeExpr6500 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_timestampLiteral_in_constant1585 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_TinyintLiteral_in_constant1633 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_trfmClause_in_selectClause196 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_truncateTableStatement_in_ddlStatement1671 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_colType12498 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_listType13019 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_mapType13111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_unionType_in_type12590 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_uniqueJoinExpr_in_uniqueJoinSource376 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_uniqueJoinSource_in_joinSource336 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_uniqueJoinSource_in_joinSource342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_uniqueJoinToken_in_joinSource333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_unlockDatabase_in_ddlStatement1815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_unlockStatement_in_ddlStatement1799 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_updateStatement_in_execStatement1263 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_valueRowConstructor_in_valuesTableConstructor1939 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_valueRowConstructor_in_valuesTableConstructor1944 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_valuesClause_in_regularBody13701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_valuesClause_in_virtualTableSource2009 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_valuesTableConstructor_in_valuesClause1980 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_viewName_in_dropViewStatement10037 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_viewPartition_in_createViewStatement9828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_virtualTableSource_in_fromSource909 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
FOLLOW_whenExpression_in_atomExpression2095 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_whereClause_in_body15009 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_body15161 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_deleteStatement15554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_selectStatement13867 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_simpleSelectStatement14843 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_updateStatement15667 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_body15051 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_body15203 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_selectStatement13923 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_setOpSelectStatement14578 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_simpleSelectStatement14868 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_clause_in_synpred16_HiveParser14863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_window_defn_in_window_clause1060 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_defn_in_window_clause1065 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_boundary_in_window_range_expression1236 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_boundary_in_window_range_expression1242 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_boundary_in_window_value_expression1300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_boundary_in_window_value_expression1306 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_in_window_specification1155 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_start_boundary_in_window_range_expression1216 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_frame_start_boundary_in_window_value_expression1280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_range_expression_in_window_frame1185 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_specification_in_function1087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FOLLOW_window_specification_in_window_defn1105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_window_value_expression_in_window_frame1190 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
FOLLOW_withAdminOption_in_grantRole7916 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_withClause_in_queryStatementExpression13253 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_withClause_in_selectStatementWithCTE14954 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_withGrantOption_in_grantPrivileges7790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
footer - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
FOOTER_COUNT - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
FooterBuffer - Class in org.apache.hadoop.hive.ql.exec
 
FooterBuffer() - Constructor for class org.apache.hadoop.hive.ql.exec.FooterBuffer
 
FOOTERLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
FOOTERLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
forget() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
Lets go of any references to a hash map.
forget() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
forget() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
Forget about the most recent hash table lookup or contains call.
forget() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
forget() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult
 
forget() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet.HashSetResult
 
forgetBatch() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
forgetBatch() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
forgetBatchOnExit() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRowDynBatch
 
forgetBatchOnExit() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRowDynBatch
 
forList(GroupType, ConverterParent, int) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
forMap(GroupType, ConverterParent, int) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
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.
format - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
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
formatPercent(double, int) - Static method in class org.apache.hive.common.util.HiveStringUtils
Format a percentage for presentation to the user.
formatStrings - Variable in class org.apache.hive.common.util.TimestampParser
 
formatTime(long) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given the time in long milliseconds, returns a String in the format Xhrs, Ymins, Z sec.
formatTimeDiff(long, long) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given a finish and start time in long milliseconds, returns a String in the format Xhrs, Ymins, Z sec, for the time difference between two times.
forNoop() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
forward(Object) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator.MapOpCtx
 
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
FORWARD - Static variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
forward(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Passes an output row to the collector.
forwardBigTableBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
Forward the big table batch to the children.
forwardCache - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
 
forwardOverflow() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
Forward the overflow batch and reset the batch.
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
 
FosterStorageHandler - Class in org.apache.hive.hcatalog.mapreduce
This class is used to encapsulate the InputFormat, OutputFormat and SerDe artifacts of tables which don't define a SerDe.
FosterStorageHandler(String, String, String) - Constructor for class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
FosterStorageHandler(Class<? extends InputFormat>, Class<? extends OutputFormat>, Class<? extends SerDe>) - Constructor for class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
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.
foundQuery(boolean) - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
free(T) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool.IAllocator
 
from - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Connection
 
from(DataInput) - Static method in class org.apache.hadoop.hive.hbase.DataInputInputStream
 
from(DataOutput) - Static method in class org.apache.hadoop.hive.hbase.DataOutputOutputStream
 
fromBinary(Binary) - Static method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
fromClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
fromCode(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
Get the ColumnEncoding which has the given code.
fromHiveTypeName(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
fromName(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
fromProperties(Properties) - Method in class org.apache.hive.beeline.DriverInfo
 
fromSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
fromStatement(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromString(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
fromString(String) - Static method in enum org.apache.hive.service.auth.SaslQOP
 
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
 
fromTTypeQualifiers(TTypeQualifiers) - Static method in class org.apache.hive.service.cli.TypeQualifiers
 
fromType(HCatFieldSchema.Type) - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Category
 
fromTypeInfo(PrimitiveTypeInfo) - Static method in class org.apache.hive.service.cli.TypeQualifiers
 
fs - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
fs - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
fs - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
fsp - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
FULLBITS_31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Mask to convert an int to an unsigned int.
FULLBITS_32 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Max unsigned integer.
FULLBITS_63 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Mask to convert a long to an unsigned long.
FullMapEqualComparer - Class in org.apache.hadoop.hive.serde2.objectinspector
 
FullMapEqualComparer() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.FullMapEqualComparer
 
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(BytesColumnVector, long[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
func(BytesColumnVector, long[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToString
 
func(LongColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToBoolean
 
func(DoubleColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDouble
 
func(LongColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToLong
 
func(BytesColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToString
 
func(LongColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToTimestamp
 
func(DecimalColumnVector, DoubleColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDoubleToDecimal
 
func(DecimalColumnVector, LongColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDecimal
 
func(BytesColumnVector, long[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToString
 
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
Do right trim and truncate for CHAR.
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
Do right trim and truncate for CHAR.
func(DecimalColumnVector, BytesColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
Convert input string to a decimal, at position i in the respective vectors.
func(DecimalColumnVector, LongColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDecimal
 
func(BytesColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
func(DoubleColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
func(LongColumnVector, DecimalColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
func(DecimalColumnVector, DoubleColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
func(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
func(DecimalColumnVector, LongColumnVector, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
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(BytesColumnVector, long[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
func(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
func(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
func(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLTrim
LTRIM element i of the vector, and place the result in outV.
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringRTrim
RTRIM element i of the vector, and place the result in outV.
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringTrim
TRIM element i of the vector, eliminating blanks from the left and right sides of the string, and place the result in outV.
func(BytesColumnVector, byte[][], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
func(BytesColumnVector, long[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateLong
 
FuncAbsDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncAbsDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
FuncAbsDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
FuncAbsDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncAbsDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
FuncAbsDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
FuncAbsLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncAbsLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
FuncAbsLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
FuncACosDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncACosDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
FuncACosDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
FuncACosLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncACosLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
FuncACosLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
FuncASinDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncASinDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
FuncASinDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
FuncASinLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncASinLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
FuncASinLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
FuncATanDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncATanDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
FuncATanDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
FuncATanLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncATanLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
FuncATanLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
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
 
FuncCeilDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncCeilDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
FuncCeilDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
FuncCeilDoubleToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncCeilDoubleToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
FuncCeilDoubleToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
FuncCeilLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncCeilLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
FuncCeilLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
FuncCosDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncCosDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
FuncCosDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
FuncCosLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncCosLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
FuncCosLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
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
 
FuncDegreesDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncDegreesDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
FuncDegreesDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
FuncDegreesLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncDegreesLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
FuncDegreesLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
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
 
FuncExpDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncExpDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
FuncExpDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
FuncExpLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncExpLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
FuncExpLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
FuncFloorDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncFloorDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
FuncFloorDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
FuncFloorDoubleToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncFloorDoubleToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
FuncFloorDoubleToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
FuncFloorLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncFloorLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
FuncFloorLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
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
 
FuncLnDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLnDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
FuncLnDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
FuncLnLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLnLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
FuncLnLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
FuncLog10DoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLog10DoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
FuncLog10DoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
FuncLog10LongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLog10LongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
FuncLog10LongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
FuncLog2DoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLog2DoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
FuncLog2DoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
FuncLog2LongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncLog2LongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
FuncLog2LongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
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.
FuncNegateDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncNegateDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
FuncNegateDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
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
 
FuncRadiansDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncRadiansDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
FuncRadiansDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
FuncRadiansLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncRadiansLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
FuncRadiansLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
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
 
FuncRoundDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncRoundDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
FuncRoundDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
FuncRoundDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncRoundDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
FuncRoundDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
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
 
FuncSignDecimalToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSignDecimalToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
FuncSignDecimalToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
FuncSignDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSignDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
FuncSignDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
FuncSignLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSignLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
FuncSignLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
FuncSinDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSinDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
FuncSinDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
FuncSinLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSinLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
FuncSinLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
FuncSqrtDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSqrtDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
FuncSqrtDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
FuncSqrtLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncSqrtLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
FuncSqrtLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
FuncTanDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncTanDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
FuncTanDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
FuncTanLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
FuncTanLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
FuncTanLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
Function - Class in org.apache.hadoop.hive.metastore.api
 
Function() - Constructor for class org.apache.hadoop.hive.metastore.api.Function
 
Function(String, String, String, String, PrincipalType, int, FunctionType, List<ResourceUri>) - Constructor for class org.apache.hadoop.hive.metastore.api.Function
 
Function(Function) - Constructor for class org.apache.hadoop.hive.metastore.api.Function
Performs a deep copy on other.
function() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
function() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Function() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
Function._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
functionIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
functionIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
FunctionInfo - Class in org.apache.hadoop.hive.ql.exec
FunctionInfo.
FunctionInfo(String, String, FunctionInfo.FunctionResource...) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDF, FunctionInfo.FunctionResource...) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDAFResolver, FunctionInfo.FunctionResource...) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDTF, FunctionInfo.FunctionResource...) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, Class<? extends TableFunctionResolver>, FunctionInfo.FunctionResource...) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo.FunctionResource - Class in org.apache.hadoop.hive.ql.exec
 
FunctionInfo.FunctionResource(SessionState.ResourceType, String) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo.FunctionResource
 
FunctionInfo.FunctionType - Enum in org.apache.hadoop.hive.ql.exec
 
functionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
functionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFReflect
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
functionName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect2
 
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
 
FunctionType - Enum in org.apache.hadoop.hive.metastore.api
 
FunctionType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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(ReloadFunctionDesc) - 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.
genColLists(Operator<? extends OperatorDesc>, 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.
genColumnStatsTask(BaseSemanticAnalyzer.AnalyzeRewriteContext, List<LoadTableDesc>, List<LoadFileDesc>, List<Task<? extends Serializable>>, int) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
A helper function to generate a column stats task on top of map-red task.
generate(SparkWork) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlanGenerator
 
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.
generateColumnComments(Schema) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
generateColumnNames(Schema) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
generateColumns(Properties, List<ColumnMappings.ColumnMapping>, StringBuilder) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
Autogenerates the columns from the given serialization class
generateColumnTypes(Properties, List<ColumnMappings.ColumnMapping>, StringBuilder, Configuration) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
Autogenerates the column types from the given serialization class
generatedKeyAlwaysReturned() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
generateGraph() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
generateGroupedSplits(JobConf, Configuration, InputSplit[], float, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.SplitGrouper
Generate groups of splits, separated by schema evolution boundaries
generateGroupedSplits(JobConf, Configuration, InputSplit[], float, int, String, boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.SplitGrouper
Generate groups of splits, separated by schema evolution boundaries
generateHashMapResultMultiValue(VectorizedRowBatch, VectorMapJoinHashMapResult, int[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
Generate results for a N x M cross product.
generateHashMapResultRepeatedAll(VectorizedRowBatch, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
Generate optimized results when entire batch key is repeated and it matched the hash map.
generateHashMapResultSingleValue(VectorizedRowBatch, VectorMapJoinHashMapResult, int[], int, int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
Generate join results for a single small table value match.
generateHashMultiSetResultRepeatedAll(VectorizedRowBatch, VectorMapJoinHashMultiSetResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
Generate the inner big table only join output results for one vectorized row batch with a repeated key.
generateHashSetResultRepeatedAll(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
Generate the left semi join output results for one vectorized row batch with a repeated key.
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.
generateInitFileName(String) - Method in class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
Get the name of the script to initialize the schema for given version
generateInvalidSchemaMessage(Project, List<FieldSchema>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierUtil
 
generateJDOFilter(Configuration, Table, Map<String, Object>, ExpressionTree.FilterBuilder) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
generateJDOFilter(Configuration, Table, Map<String, Object>, ExpressionTree.FilterBuilder) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
Generates a JDO filter statement
generateJDOFilterFragment(Configuration, Table, Map<String, Object>, ExpressionTree.FilterBuilder) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Generate the JDOQL filter for the given expression tree
generateListBucketingDirName(Object) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
Generate list bucketing directory name from a row.
generateMapJoinOperator(ParseContext, JoinOperator, 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 an operator tree.
generateOuterNulls(VectorizedRowBatch, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
Generate the non matching outer join output results for one vectorized row batch.
generateOuterNullsRepeatedAll(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
Generate the non-match outer join output results for the whole repeating vectorized row batch.
generateParseException() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Generate ParseException.
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
 
generatePredicate(NodeProcessorCtx, FilterOperator, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBPartitionProcFactory.LBPRPartitionFilterPruner
 
generatePredicate(NodeProcessorCtx, FilterOperator, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBProcFactory.LBPRFilterPruner
 
generatePredicate(NodeProcessorCtx, FilterOperator, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory.FilterPPR
 
generatePredicate(NodeProcessorCtx, FilterOperator, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.FilterPruner
Generate predicate.
generateRanges(ColumnMapper, String, ExprNodeDesc) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
Encapsulates the traversal over some ExprNodeDesc tree for the generation of Accumuluo Ranges using expressions involving the Accumulo rowid-mapped Hive column
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
 
generateTaskTree(List<Task<? extends Serializable>>, ParseContext, List<Task<MoveWork>>, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
generateTaskTree(List<Task<? extends Serializable>>, ParseContext, List<Task<MoveWork>>, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
TODO: need to turn on rules that's commented out and add more if necessary.
generateTaskTree(List<Task<? extends Serializable>>, ParseContext, List<Task<MoveWork>>, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
generateTaskTree(List<Task<? extends Serializable>>, ParseContext, List<Task<MoveWork>>, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
generateTestSuites() - Method in class org.apache.hadoop.hive.ant.GenVectorTestCode
 
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
 
GenericMR - Class in org.apache.hadoop.hive.contrib.mr
This class attempts to provide a simple framework for writing Hive map/reduce tasks in java.
GenericMR() - Constructor for class org.apache.hadoop.hive.contrib.mr.GenericMR
 
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.GenericUDAFDateStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFDateStatsEvaluator High/low value will be saved in stats DB as long value representing days since epoch.
GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg
 
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.GenericUDAFNumericStatsEvaluator<V,OI extends ObjectInspector> - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
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 - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer.GenericUDAFInfo
 
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
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
 
GenericUDAFLag.GenericUDAFLagEvaluator(GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator) - 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
 
GenericUDAFLead.GenericUDAFLeadEvaluator(GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator) - 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
 
GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator(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.GenericUDAFAbstractRankEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFRank.GenericUDAFAbstractRankEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFAbstractRankEvaluator
 
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.
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
 
GenericUDAFStreamingEvaluator<T1> - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFStreamingEvaluator(GenericUDAFEvaluator, int, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator
 
GenericUDAFStreamingEvaluator.SumAvgEnhancer<T1,T2> - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFStreamingEvaluator.SumAvgEnhancer(GenericUDAFEvaluator, int, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
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
 
GenericUDFAddMonths - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFAddMonths.
GenericUDFAddMonths() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAddMonths
 
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
 
GenericUDFBaseArithmetic - Class in org.apache.hadoop.hive.ql.udf.generic
Wrapper UDF that will instantiate the proper arithmetic UDF (numeric, date, etc) depending on the argument types
GenericUDFBaseArithmetic() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseArithmetic
 
GenericUDFBaseBinary - Class in org.apache.hadoop.hive.ql.udf.generic
Base class for binary operators, overrides getDisplayString()
GenericUDFBaseBinary() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseBinary
 
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
 
GenericUDFBaseDTI - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBaseDTI() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseDTI
 
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
 
GenericUDFCbrt - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFCbrt.
GenericUDFCbrt() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCbrt
 
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
 
GenericUDFCurrentDate - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFCurrentDate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentDate
 
GenericUDFCurrentTimestamp - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFCurrentTimestamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
GenericUDFCurrentUser - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFCurrentUser() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
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
 
GenericUDFDateFormat - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFDateFormat.
GenericUDFDateFormat() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateFormat
 
GenericUDFDateSub - Class in org.apache.hadoop.hive.ql.udf.generic
UDFDateSub.
GenericUDFDateSub() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub
 
GenericUDFDBOutput - Class in org.apache.hadoop.hive.contrib.genericudf.example
GenericUDFDBOutput is designed to output data directly from Hive to a JDBC datastore.
GenericUDFDBOutput() - Constructor for class org.apache.hadoop.hive.contrib.genericudf.example.GenericUDFDBOutput
 
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
 
GenericUDFFactorial - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFFactorial
GenericUDFFactorial() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFactorial
 
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
 
GenericUDFGreatest - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "greatest(v1, v2, ..
GenericUDFGreatest() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFGreatest
 
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
 
GenericUDFInitCap - Class in org.apache.hadoop.hive.ql.udf.generic
UDFInitCap.
GenericUDFInitCap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInitCap
 
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
 
GenericUDFLastDay - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFLastDay.
GenericUDFLastDay() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLastDay
 
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
 
GenericUDFLeast - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "least(v1, v2, ..
GenericUDFLeast() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeast
 
GenericUDFLevenshtein - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFLevenshtein.
GenericUDFLevenshtein() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLevenshtein
 
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
 
GenericUDFMonthsBetween - Class in org.apache.hadoop.hive.ql.udf.generic
UDFMonthsBetween.
GenericUDFMonthsBetween() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMonthsBetween
 
GenericUDFNamedStruct - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFNamedStruct() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNamedStruct
 
GenericUDFNextDay - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFNextDay.
GenericUDFNextDay() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay
 
GenericUDFNextDay.DayOfWeek - Enum in org.apache.hadoop.hive.ql.udf.generic
 
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
 
GenericUDFOPDTIMinus - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPDTIMinus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
GenericUDFOPDTIPlus - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPDTIPlus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
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
 
GenericUDFOPNumericMinus - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPNumericMinus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericMinus
 
GenericUDFOPNumericPlus - 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.
GenericUDFOPNumericPlus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNumericPlus
 
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
 
GenericUDFSoundex - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSoundex.
GenericUDFSoundex() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSoundex
 
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
 
GenericUDFToIntervalDayTime - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIntervalDayTime Example usage: ...
GenericUDFToIntervalDayTime() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToIntervalDayTime
 
GenericUDFToIntervalYearMonth - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIntervalYearMonth Example usage: ...
GenericUDFToIntervalYearMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToIntervalYearMonth
 
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
 
GenericUDFTrunc - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFTrunc.
GenericUDFTrunc() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTrunc
 
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
 
GenericUDTFCount2 - Class in org.apache.hadoop.hive.contrib.udtf.example
GenericUDTFCount2 outputs the number of rows seen, twice.
GenericUDTFCount2() - Constructor for class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFCount2
 
GenericUDTFExplode - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFExplode.
GenericUDTFExplode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
GenericUDTFExplode2 - Class in org.apache.hadoop.hive.contrib.udtf.example
GenericUDTFExplode2.
GenericUDTFExplode2() - Constructor for class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFExplode2
 
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.optimizer.calcite.translator.JoinCondTypeCheckProcFactory
 
genExprNode(ASTNode, TypeCheckCtx) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
genExprNode(ASTNode, TypeCheckCtx, TypeCheckProcFactory) - 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.
genExprNodeDesc(Operator, int, int, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Build ExprNodeColumnDesc for the projections in the input operator from sartpos to endpos(both included).
genFileSinkPlan(String, QB, Operator) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
GenHiveTemplate - Class in org.apache.hadoop.hive.ant
Generates hive-default.xml.template from HiveConf.ConfVars
GenHiveTemplate() - Constructor for class org.apache.hadoop.hive.ant.GenHiveTemplate
 
genIncludedColumns(List<OrcProto.Type>, List<Integer>, boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
genIncludedColumns(List<OrcProto.Type>, Configuration, boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
Take the configuration and figure out which columns we need to include.
genJoinKeys - Variable in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
genLocalJarForTest(String, String) - Static method in class org.apache.hive.common.util.HiveTestUtils
 
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
 
genPlan(QB, boolean) - 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.
genSelectDIAST(RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
genSelectPlan(ParseContext, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
GenSparkProcContext - Class in org.apache.hadoop.hive.ql.parse.spark
GenSparkProcContext maintains information about the tasks and operators as we walk the operator tree to break them into SparkTasks.
GenSparkProcContext(HiveConf, ParseContext, List<Task<MoveWork>>, List<Task<? extends Serializable>>, Set<ReadEntity>, Set<WriteEntity>, Map<String, Operator<? extends OperatorDesc>>) - Constructor for class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
GenSparkSkewJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
Copied from GenMRSkewJoinProcessor.
GenSparkUtils - Class in org.apache.hadoop.hive.ql.parse.spark
GenSparkUtils is a collection of shared helper methods to produce SparkWork Cloned from GenTezUtils.
GenSparkUtils() - Constructor for class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
GenSparkWork - Class in org.apache.hadoop.hive.ql.parse.spark
GenSparkWork separates the operator tree into spark tasks.
GenSparkWork(GenSparkUtils) - Constructor for class org.apache.hadoop.hive.ql.parse.spark.GenSparkWork
Constructor takes utils as parameter to facilitate testing
GenSparkWorkWalker - Class in org.apache.hadoop.hive.ql.parse.spark
Walks the operator tree in DFS fashion.
GenSparkWorkWalker(Dispatcher, GenSparkProcContext) - Constructor for class org.apache.hadoop.hive.ql.parse.spark.GenSparkWorkWalker
constructor of the walker - the dispatcher is passed.
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
GenTezUtils() - Constructor for class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
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.
GenVectorCode - Class in org.apache.hadoop.hive.ant
This class generates java classes from the templates.
GenVectorCode() - Constructor for class org.apache.hadoop.hive.ant.GenVectorCode
 
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)
genVectorStructExpressionWritables(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Compiles the appropriate vector expression writers based on a struct object inspector.
GenVectorTestCode - Class in org.apache.hadoop.hive.ant
GenVectorTestCode.
GenVectorTestCode(String, String) - Constructor for class org.apache.hadoop.hive.ant.GenVectorTestCode
 
GenVectorTestCode.TestSuiteClassName - Enum in org.apache.hadoop.hive.ant
 
get(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
get(int) - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
get(String, ColumnEncoding, String, TypeInfo) - Static method in class org.apache.hadoop.hive.accumulo.columns.ColumnMappingFactory
Generate the proper instance of a ColumnMapping
get() - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListCreateHelper
 
get() - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListMutateHelper
 
get(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
get(String) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
 
get(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
get(DataInput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Get a thread-local typed bytes input for the supplied DataInput.
get(DataOutput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Get a thread-local typed bytes output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable output for the supplied DataOutput.
get(String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
Return aggregate stats for a column from the cache or null.
get() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get(PartitionSpec) - Static method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.Factory
Factory method.
get(List<PartitionSpec>) - Static method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.Factory
Factory method to construct CompositePartitionSpecProxy.
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(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
get(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
get(MapJoinKey) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinPersistableTableContainer
 
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(Configuration) - 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(String) - Method in class org.apache.hadoop.hive.ql.io.StorageFormatFactory
 
get(Configuration, Class<?>) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
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(ReplicationSpec.KEY) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
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(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
 
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(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Gets the BytesRefWritable at the specified position.
get(Object) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
get() - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
get(boolean) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
get() - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBooleanObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyByteObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDoubleObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyFloatObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyIntObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyLongObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyShortObjectInspector
 
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.BooleanObjectInspector
Get the boolean data.
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.ByteObjectInspector
Get the byte data.
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.DoubleObjectInspector
Get the double data.
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.FloatObjectInspector
Get the float data.
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.IntObjectInspector
Get the int data.
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.LongObjectInspector
Get the long data.
get(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.ShortObjectInspector
Get the short data.
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBooleanObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDoubleObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableFloatObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableIntObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableLongObjectInspector
 
get(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableShortObjectInspector
 
get(int) - Method in class org.apache.hive.common.util.BloomFilter.BitSet
Returns true if the bit is set in the specified index.
get() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
get() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
get(int) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
get(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
get(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
get(String, HCatSchema, Class) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
get(int) - Method in interface org.apache.hive.hcatalog.data.HCatRecordable
Gets the field at the specified index.
get(int) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
get(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
get(String) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
get(int) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
get() - Static method in class org.apache.hive.hcatalog.data.transfer.state.DefaultStateProvider
 
get(int) - Method in class org.apache.hive.service.cli.Column
 
get_aggr_stats_for(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_aggr_stats_for(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_aggr_stats_for(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_aggr_stats_for(PartitionsStatsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_aggr_stats_for(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_aggr_stats_for(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
get_aggr_stats_for(String, String, List<String>, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
get_all_databases(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_all_databases(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_all_databases() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_all_databases() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_all_tables(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_all_tables(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_all_tables(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_config_value(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_config_value(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_config_value(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Returns the value of the given configuration variable name.
get_current_notificationEventId(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_current_notificationEventId(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_current_notificationEventId() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_current_notificationEventId() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_current_notificationEventId() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_database(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_database(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_database(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_database(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_database_core(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Equivalent to get_database, but does not write to audit logs, or fire pre-event listners.
get_databases(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_databases(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_databases(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_databases(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_databases(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_delegation_token(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_delegation_token(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_delegation_token(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_delegation_token(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_delegation_token(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_fields(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_fields(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_fields(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_fields_with_environment_context(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_fields_with_environment_context(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_fields_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_fields_with_environment_context(String, String, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_fields_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_function(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_function_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_function(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_function_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_function(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_function(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_function(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_functions(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_functions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_functions(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_functions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_functions(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_functions(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_functions(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_index_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_index_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_index_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_index_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_index_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_index_names(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_indexes(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_indexes(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_indexes(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_next_notification(NotificationEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_next_notification_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_next_notification(NotificationEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_next_notification_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_next_notification(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_next_notification(NotificationEventRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_next_notification(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_open_txns(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_open_txns(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_open_txns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_open_txns() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_open_txns() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_open_txns_info(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_info_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_open_txns_info(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_info_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_open_txns_info() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_open_txns_info() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_open_txns_info() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_part_specs_by_filter(String, String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_part_specs_by_filter(String, String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_part_specs_by_filter(String, String, String, int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_part_specs_by_filter(String, String, String, int) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_part_specs_by_filter(String, String, String, int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_column_statistics(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_column_statistics(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_column_statistics(String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_names(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_names_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_names_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_names_ps(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_with_auth(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_with_auth(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_by_expr(PartitionsByExprRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_by_expr(PartitionsByExprRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_by_expr(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_by_expr(PartitionsByExprRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_by_expr(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_by_filter(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_by_filter(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_by_filter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_by_names(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_by_names(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_by_names(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_by_names(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_by_names(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_ps(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_pspec(String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_pspec(String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_pspec(String, String, int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_pspec(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_pspec(String, String, int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_statistics_req(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_statistics_req(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_statistics_req(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_statistics_req(PartitionsStatsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_statistics_req(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_with_auth(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_with_auth(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_principals_in_role(GetPrincipalsInRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_principals_in_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_principals_in_role(GetPrincipalsInRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_principals_in_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_principals_in_role(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_principals_in_role(GetPrincipalsInRoleRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_principals_in_role(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_principals_in_role(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
get_principals_in_role(GetPrincipalsInRoleRequest) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
get all role-grants for users/roles that have been granted the given role Note that in the returned list of RolePrincipalGrants, the roleName is redundant as it would match the role_name argument of this function
get_privilege_set(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_privilege_set(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Return the privileges that the user, group have directly and indirectly through roles on the given hiveObject
get_privilege_set(HiveObjectType, String, String, List<String>, String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
get_privilege_set(HiveObjectType, String, String, List<String>, String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
get all role-grants for roles that have been granted to given principal Note that in the returned list of RolePrincipalGrants, the principal information redundant as it would match the principal information in request
get_role_names(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_role_names(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_role_names() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_role_names() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_schema(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_schema(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_schema(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Return the schema of the table.
get_schema_with_environment_context(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_schema_with_environment_context(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_schema_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_schema_with_environment_context(String, String, EnvironmentContext) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_schema_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Return the schema of the table.
GET_SPLITS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
get_table(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_table_column_statistics(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table_column_statistics(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table_column_statistics(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_table_core(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Equivalent of get_table, but does not log audits and fire pre-event listener.
get_table_names_by_filter(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table_names_by_filter(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table_names_by_filter(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table_names_by_filter(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table_names_by_filter(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_table_objects_by_name(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table_objects_by_name(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table_objects_by_name(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table_objects_by_name(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table_objects_by_name(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Gets multiple tables from the hive metastore.
get_table_statistics_req(TableStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table_statistics_req(TableStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table_statistics_req(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table_statistics_req(TableStatsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table_statistics_req(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_tables(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_tables(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_tables(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_tables(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_tables(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_type(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_type(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_type_all(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_type_all(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_type_all(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_type_all(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_type_all(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getAborted() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getAbortedIterator() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getAbortedSize() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getAbortReasons() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
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.
getAccessedColumns() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getAccumuloInstanceName() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getAccumuloKeytab() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getAccumuloPassword() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getAccumuloTableName() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getAccumuloUserName() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getAcidEventFields() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
getAcidFileSinks() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getAcidOperation() - Method in class org.apache.hadoop.hive.ql.Context
 
getAcidRecordUpdater(JobConf, TableDesc, int, FileSinkDesc, Path, ObjectInspector, Reporter, int) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getAcidState(Path, Configuration, ValidTxnList) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Get the ACID state of the given directory.
getAclStatus() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.Hadoop23FileStatus
 
getAcquiredat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getActionType(Entity) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getActionType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
getActiveAuthorizer() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getActiveConf() - Method in class org.apache.hadoop.hive.metastore.RetryingHMSHandler
 
getAddCursor() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getAddedJars() - Method in interface org.apache.hive.spark.client.JobContext
Return all added jar path which added through AddJarJob.
getAdditionalCounters() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getAdditionalSemanticInputs() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getAddPartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAddPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getAddPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize AddPartitionMessage instance.
getAddress() - Method in class org.apache.hive.spark.client.rpc.RpcServer
 
getAddTime() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getAfterCol() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
getAggrColStatsFor(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getAggrColStatsFor(String, String, List<String>, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getAggrColStatsFor(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getAggregateCost(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel
 
getAggregateCost(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel
 
getAggregateCost(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel
 
getAggregateFunction() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
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.gen.VectorUDAFAvgDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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
 
getAggregator(Configuration) - Method in enum org.apache.hadoop.hive.common.StatsSetupConst.StatDB
 
getAggregatorExpression(AggregationDesc, boolean) - 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
 
getAint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.optimizer.index.RewriteCanApplyCtx
 
getAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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
 
getAliases(Node) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinerPPD
 
getAliases(Node) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinPPD
 
getAliasFilter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
getAliasFilter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
getAliasFilter() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
getAliasFilter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
getAliasId(String, QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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
 
getAliasToNewAliasMap() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getAliasToOpInfo() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getAliasToOpInfo() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
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
 
getAll() - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
getAll() - Method in interface org.apache.hive.hcatalog.data.HCatRecordable
Gets all the fields of the hcat record.
getAll() - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
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.
getAllColumns() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
getAllColumnsInformation(List<FieldSchema>, boolean, boolean, List<ColumnStatisticsObj>) - 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.metastore.HiveMetaStoreClient
Get the names of all databases in the MetaStore.
getAllDatabases() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all databases in the MetaStore.
getAllDatabases() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getAllDatabases() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getAllDatabases() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing database names.
getAllDelegationTokenIdentifiers() - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
getAllDelegationTokenIdentifiers() - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
List of all token identifiers in the store.
getAllDelegationTokenIdentifiers() - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
getAllDelegationTokenIdentifiers() - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
getAllExprToColumnAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAllForType(TempletonStorage.Type) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
getAllForType(TempletonStorage.Type) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
Get the id of each data grouping of a given type in the storage system.
getAllForType(TempletonStorage.Type) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
getAllIndexes(Table, short) - Static method in class org.apache.hadoop.hive.ql.optimizer.IndexUtils
 
getAllJobs() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Get all the jobs submitted.
getAllJobs() - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Get all the jobs submitted.
getAllJobs() - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Get all the jobs submitted.
getAllLeafOperators() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
Returns a set containing all leaf operators from the operator tree in this work.
getAllMetrics() - Method in class org.apache.hive.spark.client.MetricsCollection
 
getAllOperators() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getAllOperators() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getallowAllColRef() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getAllowDistinctFunctions() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getallowFunctionStar() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getAllowGBExprElimination() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getallowIndexExpr() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getAllowStatefulFunctions() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getallowSubQueryExpr() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getallowWindowing() - 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.
getAllProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getAllReduceSinkOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getAllReduceWork() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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.HiveV1Authorizer
 
getAllRoles() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getAllRoles() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
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.MergeJoinWork
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
getAllStructFieldNames() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
Returns all the fields.
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getAllStructFieldTypeInfos() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getAllTables(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all tables in the specified database.
getAllTables(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all tables in the specified database.
getAllTables(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getAllTables(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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.
getAllTables(String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
getAllTokenIdentifiers() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getAllTokenIdentifiers() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getAllUnionObjectTypeInfos() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getAllWindowingSpecs() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getAllWork() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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.SparkWork
 
getAllWorkUnsorted() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getAlterDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterIdColumn() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares ALTER TABLE query
getAlterIndexDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlternateMappings(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getAlterPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getAlterPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to deserialize AlterPartitionMessage
getAlterTableAlterPartDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTableExchangePartition() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getAlterTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize AlterTableMessge
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
 
getAnalyzer() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getAnalyzeRewrite() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getAnalyzeRewrite() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
getAndOr() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.apache.hive.common.util.AnnotationUtils
 
getAnnotation(Method, Class<T>) - Static method in class org.apache.hive.common.util.AnnotationUtils
 
getAnyKey() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getAnyKey() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getAnyKey() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
getAnyKey() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
getAnyKey() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
getAppConfigInstance() - Static method in class org.apache.hive.hcatalog.templeton.Main
Retrieve the config singleton.
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.metastore.MetaStoreUtils
 
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.gen.IfExprDoubleColumnDoubleColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getArgDescs() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getArgOrder(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
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
 
getArgsExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getArgsExplain() - 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
 
getArray(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getArray(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getArray(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getArray(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getArrayElementSchema() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getArrayElementType(Type) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Returns the array element type, if the Type is an array (Object[]), or GenericArrayType (Map[]).
getArrayEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getAscending() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Returns true in UDAFMaxN, and false in UDAFMinN.
getAscending() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxN.UDAFMaxNEvaluator
 
getAscending() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMinN.UDAFMinNEvaluator
 
getAsciiStream(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getAsciiStream(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getAst() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryTypeDef
 
getAst() - Method in class org.apache.hadoop.hive.ql.plan.ExplainSQRewriteWork
 
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
 
getAString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
getAstStringTree() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.Factory
 
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
 
getAt(int) - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
getAttribute(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getAttributes(String[]) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getAttributes() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAttributes(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getAttributesSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAuth() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getAuthenticationProvider(AuthenticationProviderFactory.AuthMethods) - Static method in class org.apache.hive.service.auth.AuthenticationProviderFactory
 
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
 
getAuthMethod() - Method in enum org.apache.hive.service.auth.AuthenticationProviderFactory.AuthMethods
 
getAuthName() - Method in enum org.apache.hive.service.auth.HiveAuthFactory.AuthTypes
 
getAuthorityList() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getAuthorizationID() - Method in class org.apache.hive.service.auth.PlainSaslServer
 
getAuthorizationMode() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizationProvider() - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
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
getAuthorizationProvider() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
getAuthorizations() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
Extracts the table property to allow dynamic Accumulo Authorizations to be used when reading data from an Accumulo table.
getAuthorizationsFromConf(Configuration) - Static method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
Extract any configuration on Authorizations to be used from the provided Configuration.
getAuthorizationsFromValue(String) - Static method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
Create an Authorizations object when the provided value is not null.
getAuthorizeProviderManager(Configuration, String, 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.
getAuthorizerInterface() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizerV2() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthProcFactory(ThriftCLIService) - Method in class org.apache.hive.service.auth.HiveAuthFactory
Returns the thrift processor factory for HiveServer2 running in binary mode
getAuthProvider() - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
getAuthTransFactory() - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getAutoCommit() - Method in class org.apache.hive.jdbc.HiveConnection
 
getAuxJars() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getAvailableMemory(Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
 
getAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
getAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
getAvgColLen() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getAvgColLen() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
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
 
getBackgroundHandle() - Method in class org.apache.hive.service.cli.operation.Operation
 
getBackupChildrenTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBackupTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBadRecords() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMDatabaseURIRetVal
 
getBadRecords() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMStorageDescriptorTblURIRetVal
 
getBadRecords() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdatePropURIRetVal
 
getBadRecords() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateSerdeURIRetVal
 
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
 
getBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getBaseBigAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getBaseCols() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getBaseConfiguration() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
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
 
getBaseName(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
getBaseSplit() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
Gets the underlying InputSplit.
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getBaseToIdxTableMap() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getBaseWorkList() - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
getBasicStat() - Static method in class org.apache.hadoop.hive.hbase.HBaseStatsUtils
Returns the basic type of the supported statistics.
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
 
getBeginColumn() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getBeginLine() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getBigDecimal(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(int, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(String, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBigDecimal(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBigDecimal(int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
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
 
getBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
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
 
getBigTablePosition() - Method in class org.apache.hadoop.hive.ql.plan.CommonMergeJoinDesc
 
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(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getBinaryFromText(Text) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getBinarySortable() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getBinaryStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
getBinaryStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getBinaryStorage() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getBinaryStream(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBinaryStream(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBinaryVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getBinaryValue(ConstantObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
Attempts to construct the binary value from the given inspector.
getBinaryValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getBitset(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
getBitset(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
repeated fixed64 bitset = 2;
getBitset(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterOrBuilder
repeated fixed64 bitset = 2;
getBitSet() - Method in class org.apache.hive.common.util.BloomFilter
 
getBitsetCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
getBitsetCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
repeated fixed64 bitset = 2;
getBitsetCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterOrBuilder
repeated fixed64 bitset = 2;
getBitsetList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
getBitsetList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
repeated fixed64 bitset = 2;
getBitsetList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterOrBuilder
repeated fixed64 bitset = 2;
getBitSize() - Method in class org.apache.hive.common.util.BloomFilter
 
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
 
getBlob(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBlob(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBlob(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBlob(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBlockSize() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getBloomFilter() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache.AggrColStats
 
getBloomFilter(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilter(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilter(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndexOrBuilder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndexOrBuilder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndexOrBuilder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndexOrBuilder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
repeated .orc.proto.BloomFilter bloomFilter = 1;
getBloomFilterOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndexOrBuilder
repeated .orc.proto.BloomFilter bloomFilter = 1;
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
 
getBoolean(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the boolean value out of a primitive object.
getBoolean(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getBoolean(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBoolean(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBoolean(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBoolean(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBooleanStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getBoolExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get BoolExprProcessor.
getBoolVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getBoolVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getBoolVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getBoolVar(Configuration, HiveConf.ConfVars, boolean) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getBoolVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getBottomReduceSinkOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getBranch() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the branch on which this originated.
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.metastore.api.StorageDescriptor
 
getBucketCols() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
getBucketCols() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getBucketCols() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the bucket columns.
getBucketCols() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the bucket columns.
getBucketColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getBucketColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
getBucketFileNameFromPathSubString(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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
getBucketStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBucketStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
getBuffer(boolean, int) - Method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils.ByteBufferAllocatorPool
 
getBuffer(boolean, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.ByteBufferPoolShim
Get a new ByteBuffer from the pool.
getBuffer() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
getBufferFromBytes(byte[]) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getBufferFromDecimal(HiveDecimal, int) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getBufferPosition() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
getBufferSize() - Method in class org.apache.hadoop.hive.ql.plan.CollectDesc
 
getBufferType() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
getBuildVersion() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Returns the buildVersion which includes version, revision, user and date.
getByte(String, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Return the byte value of the number string.
getByte(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the byte value out of a primitive object.
getByte(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getByte(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getByte(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getByte(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getByte(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getByteArray(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getByteBuffer(int) - Method in class org.apache.hive.common.util.Decimal128FastBuffer
 
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.serde2.io.TimestampWritable
Used to create copies of objects
getBytes() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
Return the data in bytes corresponding to this given struct.
getBytes() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
getBytes(int) - Method in class org.apache.hive.common.util.Decimal128FastBuffer
 
getBytes(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBytes(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getBytes(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBytes(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getBytesCopy() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Returns a copy of the underlying bytes referenced by this instance.
getByteSegmentRefToCurrent(WriteBuffers.ByteSegmentRef, int, WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getBytesFromByteBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getBytesRemainingInBuffer() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
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
 
getByteVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getByteVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getByteValue(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getCache(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.ObjectCacheFactory
Returns the appropriate cache
getCachedRDDIds() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
getCachedRow() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
For testing purposes.
getCalciteAggFn(String, ImmutableList<RelDataType>, RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
getCalciteFn(String, ImmutableList<RelDataType>, RelDataType, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
getCalciteOperator(String, GenericUDF, ImmutableList<RelDataType>, RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
getCallback() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The url callback
getCandidateFilterOps() - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getCanonicalErrorMsg() - Method in exception org.apache.hadoop.hive.ql.metadata.HiveException
 
getCatalog() - Method in class org.apache.hive.jdbc.HiveConnection
 
getCatalogName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
getCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
getCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getCatalogs() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getCatalogs(SessionHandle) - Method in class org.apache.hive.service.cli.CLIService
 
getCatalogs(SessionHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getCatalogs(SessionHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
getCatalogs() - Method in interface org.apache.hive.service.cli.session.HiveSession
getCatalogs operation handler
getCatalogs() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetCatalogs(TGetCatalogsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetCatalogs_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetCatalogs(TGetCatalogsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetCatalogs_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetCatalogs(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetCatalogs(TGetCatalogsReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetCatalogs(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getCatalogs(SessionHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getCatalogSeparator() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
GetCatalogsOperation - Class in org.apache.hive.service.cli.operation
GetCatalogsOperation.
GetCatalogsOperation(HiveSession) - Constructor for class org.apache.hive.service.cli.operation.GetCatalogsOperation
 
getCatalogTerm() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getCategory() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector
An ObjectInspector must inherit from one of the following interfaces if getCategory() returns: PRIMITIVE: PrimitiveObjectInspector LIST: ListObjectInspector MAP: MapObjectInspector STRUCT: StructObjectInspector.
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the associated category this primitive ObjectInspector.
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
Returns the category of this TypeInfo.
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
The Category of this TypeInfo.
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getCategory() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
Returns category of the field
getCategory() - Method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
 
getCboInfo() - Method in class org.apache.hadoop.hive.ql.Context
 
getCboInfo() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getCD() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getCf() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
getCfg() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getChangedProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getChar(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getCharacterLength() - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
getCharacterLength() - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
getCharacterLength() - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
getCharacterLength() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
getCharacterLengthForType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Return the character length of the type
getCharacterMaximumLength() - Method in class org.apache.hive.service.cli.TypeQualifiers
 
getCharacterStream(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getCharacterStream(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getCharacterStream(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getCharacterStream(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getCharTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getCharTypeInfo(int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getCheckerFactories() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getCheckerFactories() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColLikeStringScalar
 
getCheckerFactories() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColRegExpStringScalar
 
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
 
getChildList(CuratorFramework) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
Get the list of jobs from JobState
getChildOperator(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
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(SparkTran) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
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.api.Adjacency
 
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.SparkWork
getChildren returns all the nodes with edges leading out of work
getChildren(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getChildren returns all the nodes with edges leading out of work
getChildren() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
getChildren() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Get a list of jobstates for jobs that are children of this job.
getChildrenIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getChildrenSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getChildTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getChildTasks(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
getClass(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getClassLoader() - Static method in class org.apache.hadoop.hive.common.JavaUtils
Standard way of getting classloader in Hive code (outside of Hadoop).
getClassName() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getClassName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getClassName() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getClassName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
getClassName() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getClassNames() - Static method in class org.apache.hive.beeline.ClassNameCompleter
 
getClauseNames() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getClauseNamesForDest() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getCleanupScript() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getClient(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client.Factory
 
getClient_protocol() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getClientConfiguration(String, String, boolean) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Construct a ClientConfiguration instance in a backwards-compatible way.
getClientInfo() - Method in class org.apache.hive.jdbc.HiveConnection
 
getClientInfo(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
getClientInfoProperties() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getClientIp() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getClientJobId() - Method in interface org.apache.hive.spark.client.JobHandle
The client job ID.
getClientType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
getClientType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext
 
getClientUGI() - Method in class org.apache.hadoop.hive.thrift.TUGIContainingTransport
 
getClob(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getClob(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getClob(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getClob(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getCloneToWork() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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.
getClusterMode() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getClusterStatus() - Method in class org.apache.hadoop.hive.ql.Driver
Return the status information about the Map-Reduce cluster
getClusterStatus(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getClusterStatus(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getClusterStatus() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
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 enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
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.metastore.api.Order
 
getCol() - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
getCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
getCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
getCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
getCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
getColInfoMap(List<T>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getCollation(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getCollation(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getCollation(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getCollation(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getCollation(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getCollation(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getCollation() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getCollationList() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
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.metastore.api.ColumnStatisticsObj
 
getColName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getColName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getColName() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
getColName() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
getColNameIndxMap(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getColNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getColNames() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
getColNames() - Method in class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
getColNames() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getColNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getColNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
getColNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getColNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
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.gen.CastDateToBooleanViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.StringGroupColConcatStringScalar
 
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.StringScalarConcatStringGroupCol
 
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.gen.DateColAddIntervalDayTimeColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
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.StringGroupConcatColCol
 
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.gen.DateColAddIntervalDayTimeColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
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.StringGroupConcatColCol
 
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.metastore.api.StorageDescriptor
 
getCols() - Method in class org.apache.hadoop.hive.metastore.model.MColumnDescriptor
 
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
 
getCols() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getCols() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the columns.
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.
getColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getColsString() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getColStat(List<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
getColStat(List<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getColStat(List<Integer>, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
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.
getColStatisticsUpdatingTableAlias(Statistics, RowSchema) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get column statistics from parent statistics given the row schema of its child.
getColStats() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache.AggrColStats
 
getColStats() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
getColStats() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
getColStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStats(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatisticsOrBuilder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStats() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsUpdateWork
 
getColStats() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getColStatsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatisticsOrBuilder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsIterator() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
getColStatsIterator() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
getColStatsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatisticsOrBuilder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatisticsOrBuilder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatisticsOrBuilder
repeated .orc.proto.ColumnStatistics colStats = 1;
getColStatsSize() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
getColStatsSize() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
getColType() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
getColType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getColType() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getColType() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
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() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint32 column = 2;
getColumn() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional uint32 column = 2;
getColumn() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional uint32 column = 2;
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
 
getColumn() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
Deprecated. 
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.
getColumnarStructObjectInspector(List<String>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getColumnarStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getColumnClassName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnCommentsFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getColumnCount() - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getColumnDescriptorAt(int) - Method in class org.apache.hive.service.cli.TableSchema
 
getColumnDescriptors() - Method in class org.apache.hive.service.cli.TableSchema
 
getColumnDisplaySize(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnEncoding(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
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() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory
Factory method to get ColumnExprProcessor.
getColumnExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get ColumnExprProcessor.
getColumnFamily() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
getColumnFamily() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
getColumnFamilyBytes() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
Cached bytes for the columnFamily.
getColumnIndex() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow.Assigner
 
getColumnIndex() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow.Extractor
 
getColumnIndexes() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getColumnInfo(String) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getColumnInfo(String, String) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getColumnInfos() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getColumnInternalName(int) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getColumnInternalName(int) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getColumnLabel(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnMapper(Configuration) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
getColumnMapper() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getColumnMappingForHiveColumn(List<String>, String) - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
getColumnMappingForHiveColumn(String) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getColumnMappings() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
getColumnMappings() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getColumnMappings() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getColumnMappingValue() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getColumnName() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
The name of the Hive column this is mapping
getColumnName() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveColumn
Get the name of the Hive column
getColumnName() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getColumnName(String) - Static method in class org.apache.hadoop.hive.hbase.HBaseStatsUtils
Returns the HBase column where the statistics for the given type are stored.
getColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getColumnName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getColumnName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getColumnName() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
Get the simple column name.
getColumnName(Map<String, ExprNodeDesc>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getColumnName() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getColumnName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnName() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getColumnName() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
getColumnName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getColumnNames() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getColumnNames() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
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
 
getColumnNames() - Method in class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
getColumnNames() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to columnNames.
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
 
getColumnNamesOrder(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.
getColumnObjectInspectors(List<TypeInfo>, LazySerDeParameters, List<ColumnMapping>, AccumuloRowIdFactory) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getColumnOpConstantRange(Class<? extends CompareOp>, Text) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
getColumnPath() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getColumnPrivileges(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getColumnPrivilegeSet(String, String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getColumnPrivilegeSet(String, String, String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
getColumnQualifier() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
getColumnQualifierBytes() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
Cached bytes for the columnQualifier.
getColumnQualifierPrefix() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
getColumns(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumns(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.ColumnEncoding columns = 2;
getColumns(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumns() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
Get the number of columns in the underlying rows.
getColumns(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.PrivilegeObjectDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
getColumns() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
Applicable columns in this object, when the type is HivePrivilegeObjectType.TABLE In case of DML read operations, this is the set of columns being used.
getColumns() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the columns of the table.
getColumns(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getColumns(SessionHandle, String, String, String, String) - Method in class org.apache.hive.service.cli.CLIService
 
getColumns() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
getColumns(SessionHandle, String, String, String, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getColumns(SessionHandle, String, String, String, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
getColumns(String, String, String, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
getColumns operation handler
getColumns(String, String, String, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetColumns(TGetColumnsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetColumns_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetColumns(TGetColumnsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetColumns_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetColumns(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetColumns(TGetColumnsReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetColumns(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getColumns(SessionHandle, String, String, String, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getColumns() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getColumns() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
getColumnsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsHeader(List<ColumnStatisticsObj>) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getColumnsIterator() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getColumnsIterator() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
getColumnSize() - Method in class org.apache.hive.service.cli.TypeDescriptor
The column size for this type.
getColumnsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsMapping() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
GetColumnsOperation - Class in org.apache.hive.service.cli.operation
GetColumnsOperation.
GetColumnsOperation(HiveSession, String, String, String, String) - Constructor for class org.apache.hive.service.cli.operation.GetColumnsOperation
 
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.ColumnEncoding columns = 2;
getColumnsSize() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getColumnsSize() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
getColumnStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.StripeStatistics
Return list of column statistics
getColumnStatisticsFromColName(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.accumulo.columns.ColumnMapping
The @{link TypeInfo} of the Hive column this is mapping
getColumnType() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveColumn
The Hive type of this column
getColumnType() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getColumnType() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getColumnType(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnTypeName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getColumnTypes() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
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
 
getColumnTypes() - Method in class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
getColumnTypes() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getColumnTypesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to columnTypes.
getColumnTypeValue() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getColumnVectorTypeFromTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getColVals() - Method in class org.apache.hive.service.cli.thrift.TRow
 
getColValsIterator() - Method in class org.apache.hive.service.cli.thrift.TRow
 
getColValsSize() - Method in class org.apache.hive.service.cli.thrift.TRow
 
getCombinedRR(RowResolver, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.RowResolver
Return a new row resolver that is combination of left RR and right RR.
getCombineFileInputFormat() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getCombineFileInputFormat() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getCombineFileInputFormat() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getCommand() - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHookContext
 
getCommand() - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
getCommand() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getCommand() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getCommand() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getCommandCompleter() - Static method in class org.apache.hadoop.hive.cli.CliDriver
 
getCommandParams() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getCommandString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
 
getCommandString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext
 
getCommandType() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getComment() - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
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
 
getComment() - Method in class org.apache.hive.hcatalog.api.HCatDatabase
Gets the comment.
getComment() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getComment() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getComment() - Method in class org.apache.hive.jdbc.JdbcTable
 
getComment() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getComment() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
getComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
getComments() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Gets the comments.
getComments() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
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 ...
getCompacts() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
getCompactsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
getCompactsSize() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
getCompareOp(String, IndexSearchCondition) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
getCompareOpClass(String) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
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
 
getCompatLevel(HiveConf) - Static method in class org.apache.hive.common.HiveCompat
Returned the configured compatibility level
getCompatLevel(String) - Static method in class org.apache.hive.common.HiveCompat
 
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.
getCompletedUrl() - Method in class org.apache.hive.hcatalog.templeton.Server
The callback url on this server when a task is completed.
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
 
getCompleteName(String, String) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
 
getCompleteStatus() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The status of a job once it is completed.
getCompleteTaskList() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getComponent() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getComponentIterator() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getComponentSize() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getCompressBufferSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
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 class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
getCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional .orc.proto.CompressionKind compression = 2;
getCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional .orc.proto.CompressionKind compression = 2;
getCompression() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional .orc.proto.CompressionKind compression = 2;
getCompression() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the compression kind.
getCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getCompressionBlockSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 compressionBlockSize = 3;
getCompressionBlockSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 compressionBlockSize = 3;
getCompressionBlockSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 compressionBlockSize = 3;
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.
getCompressionSize() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
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
 
getConcatQbIDAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
getConcurrency() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
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.accumulo.AccumuloConnectionParameters
 
getConf() - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
getConf() - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
getConf() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
getConf() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
getConf() - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
getConf() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getConf() - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionListener
 
getConf() - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
getConf() - Method in class org.apache.hadoop.hive.metastore.MetaStoreInitListener
 
getConf() - Method in class org.apache.hadoop.hive.metastore.MetaStorePreEventListener
 
getConf() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getConf() - Method in class org.apache.hadoop.hive.metastore.RawStoreProxy
 
getConf() - Method in class org.apache.hadoop.hive.ql.Context
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getConf() - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
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.hooks.Redactor
 
getConf() - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Deprecated.
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
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.parse.spark.OptimizeSparkProcContext
 
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
 
getConf() - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
getConf() - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
getConf() - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
getConf() - Method in enum org.apache.hive.hcatalog.common.HCatContext
Get the configuration, if there is one.
getConf() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
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
 
getConfiguration(JobContext) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getConfiguration(JobContext) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getConfiguration(JobContext) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get configuration from JobContext
getConfiguration() - Method in class org.apache.hive.service.cli.operation.Operation
 
getConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getConfigurationErrors() - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Get the error messages during the Serde configuration
getConfigurationSize() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getConfigurationSize() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getConfigValue(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getConfigValue(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getConfirmedPartitionsForScan(TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
getConfName() - Method in class org.apache.hadoop.hive.ql.plan.ShowConfDesc
 
getConfOverlay() - Method in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
getConfOverlay() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
getConfOverlaySize() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
getConfSystemProperties() - Static method in class org.apache.hadoop.hive.conf.HiveConf
This method returns a mapping from config variable name to its value for all config variables which have been set using System properties
getConfVal(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Fetch configuration value on conf that the HCatClient is instantiated against.
getConfVal(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getConfVars(String) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getConnection() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getConnection() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getConnection() - Method in class org.apache.hive.jdbc.HiveDataSource
 
getConnection(String, String) - Method in class org.apache.hive.jdbc.HiveDataSource
 
getConnection() - Method in class org.apache.hive.jdbc.HiveStatement
 
getConnectionToMetastore(String, String, boolean, HiveConf) - Static method in class org.apache.hive.beeline.HiveSchemaHelper
Get JDBC connection to metastore db
getConnectionURLExamples() - Method in class org.apache.hive.beeline.BeeLine
 
getConnector() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getConnector(Instance) - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getConsole() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
initialize or retrieve console object for SessionState.
getConsoleReader(InputStream) - Method in class org.apache.hive.beeline.BeeLine
 
getConstant(Map<String, String>) - Method in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
getConstantAsBytes(Writable) - Method in class org.apache.hadoop.hive.accumulo.predicate.PushdownTuple
 
getConstantDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getConstantIntValue(ObjectInspector[], int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getConstantLongValue(ObjectInspector[], int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getConstantObjectInspector(ObjectInspector, Object) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getConstantOpColumnRange(Class<? extends CompareOp>, Text) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
getConstantPropagateOption() - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
getConstantStringValue(ObjectInspector[], int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getConstExpr() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getConstVal() - Method in class org.apache.hadoop.hive.accumulo.predicate.PushdownTuple
 
getContainerResource(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 contentLength = 2;
getContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 contentLength = 2;
getContentLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 contentLength = 2;
getContentLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the length of the file.
getContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getContentSummary(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
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
 
getContentSummary(Path) - Method in class org.apache.hadoop.hive.shims.HiveHarFileSystem
 
getContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConvertedColNames(List<List<String>>, SelectOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.SelectRule
 
getConvertedJoinOps() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getConvertedNode(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getConvertedOI(ObjectInspector, ObjectInspector, Map<ObjectInspector, Boolean>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters
 
getConvertedOI(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters
 
getConvertedOI(ObjectInspector, ObjectInspector, Map<ObjectInspector, Boolean>, boolean) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters
Utility function to convert from one object inspector type to another.
getConverter(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
getConverter(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
getConverter(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
getConverter(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters
Returns a converter that converts objects from one OI to another OI.
getConverterFromDescription(PrimitiveType, int, ConverterParent) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
getConverterFromDescription(GroupType, int, ConverterParent) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
getConverterFromDescription(Type, int, ConverterParent) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
getcOpt() - Method in class org.apache.hadoop.hive.accumulo.predicate.PushdownTuple
 
getCorrelations() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
getCost(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getCostModel() - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel
 
getCostModel(HiveConf) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel
 
getCount() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
getCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap.Mapping
 
getCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
getCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
getCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
getCount(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
getCount(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
repeated uint64 count = 1 [packed = true];
getCount(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatisticsOrBuilder
repeated uint64 count = 1 [packed = true];
getCount() - Method in class org.apache.hadoop.hive.serde2.ByteStream.Input
 
getCount(Service.STATE) - Method in class org.apache.hive.service.BreakableService
 
getCountCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
getCountCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
repeated uint64 count = 1 [packed = true];
getCountCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatisticsOrBuilder
repeated uint64 count = 1 [packed = true];
getCountDistint() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
getCounter(String, String) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
getCounter() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getCounter() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getCounter() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getCounter() - Method in class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
getCounter(String) - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
getCounter(String, String) - Method in class org.apache.hive.spark.counter.SparkCounters
 
getCounter(Enum<?>) - Method in class org.apache.hive.spark.counter.SparkCounters
 
getCounters() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
getCountList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
getCountList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
repeated uint64 count = 1 [packed = true];
getCountList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatisticsOrBuilder
repeated uint64 count = 1 [packed = true];
getCpu() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
getCpuMSec() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getCpuProfile(int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getCq() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
getCreate(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares CREATE TABLE query
getCreated() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
When this job was created.
getCreateDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateDatabaseMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getCreateDatabaseMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize CreateDatabaseMessage instance.
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
 
getCreateParams() - Method in enum org.apache.hive.service.cli.Type
Parameters used in creating the type (may be null)
getCreateTable() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getCreateTableGrants() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCreateTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getCreateTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize CreateTableMessage instance.
getCreateTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTblLikeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getCreateTime() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the creates the time.
getCreateViewDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateVwDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
getCtx() - Method in class org.apache.hadoop.hive.ql.plan.ExplainSQRewriteWork
 
getCumulativeCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistinctRowCount
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getCumulativeMemoryWithinPhaseSplit() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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
 
getCurrent() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
getCurrent() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
getCurrent() - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Getter for the Partition "pointed to" by the iterator.
getCurrent() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
getCurrent() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
getCurrentArray() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
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
 
getCurrentDate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentDate
 
getCurrentDB() - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getCurrentDeserializer() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
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.
getCurrentFunctionNames() - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
getCurrentHostZnodePath() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getCurrentInputPath() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getCurrentIntermediateResult(GenericUDAFStreamingEvaluator.SumAvgEnhancer<T1, T2>.SumAvgStreamingState) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
getCurrentKey() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
 
getCurrentKey() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger
 
getCurrentKey() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValuesInputMerger
 
getCurrentKey() - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
getCurrentKey() - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
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
 
getCurrentNodes() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getCurrentNotificationEventId() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getCurrentNotificationEventId() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the last used notification event id.
getCurrentNotificationEventId() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getCurrentNotificationEventId() - Method in interface org.apache.hadoop.hive.metastore.RawStore
Get the last issued notification event id.
getCurrentNotificationEventId() - Method in class org.apache.hive.hcatalog.api.HCatClient
Get the most recently used notification id.
getCurrentNotificationEventId() - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getCurrentOperationLog() - Static method in class org.apache.hadoop.hive.ql.session.OperationLog
 
getCurrentReadBlockSize() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getCurrentRecord() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter
 
getCurrentReplicationState() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
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.HiveV1Authorizer
 
getCurrentRoleNames() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getCurrentRoleNames() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
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.
getCurrentRows() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
 
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
 
getCurrentTimestamp() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
getCurrentTransactionState() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
get state of current transaction
getCurrentTrashPath(Configuration, FileSystem) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getCurrentTrashPath(Configuration, FileSystem) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getCurrentTrashPath(Configuration, FileSystem) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getCurrentTxn() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCurrentTxnId() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Get Id of currently open transaction
getCurrentUGIWithConf(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
getCurrentUser() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
getCurrentValue() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger
 
getCurrentValue() - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
getCurrentValue() - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
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.KeyValuesInputMerger
 
getCurrMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrTopOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrUnionOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCursorName() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getD() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getData() - Method in class org.apache.hadoop.hive.common.DiskRange
 
getData() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
getData() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getData() - Method in class org.apache.hadoop.hive.ql.exec.tez.DataInputByteBuffer
 
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
 
getData() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Returns the underlying byte array.
getData() - Method in class org.apache.hadoop.hive.serde2.ByteStream.Input
 
getData() - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
getData() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Returns the underlying bytes.
getData() - Method in class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
getData() - Method in class org.apache.hive.common.util.BloomFilter.BitSet
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.events.CreateDatabaseEvent
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.events.DropDatabaseEvent
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.events.PreCreateDatabaseEvent
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.events.PreDropDatabaseEvent
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.events.PreReadDatabaseEvent
 
getDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a Database Object
getDatabase() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getDatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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(String) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDatabase(String, boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDatabase() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getDatabase(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
getDatabase(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets the database.
getDatabase(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getDatabaseCurrent() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get the Database object for current database
getDatabaseInternal(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabaseMajorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseMinorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Accepts qualified name which is in the form of dbname.tablename and returns dbname from it
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
 
getDatabaseName() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Deprecated.
getDatabaseName() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Gets the database name.
getDatabaseName() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getDatabaseName() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the database name.
getDatabaseName() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
Gets the value of databaseName
getDatabaseName() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Gets the value of databaseName
getDatabaseName() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getDatabasePath(Database) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getDatabaseProductName() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProductVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getDatabaseProperties() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Gets the database properties.
getDatabases(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all databases in the MetaStore that match the given pattern.
getDatabases(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all databases in the MetaStore that match the given pattern.
getDatabases(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabases(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getDatabasesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing databases that match the given pattern.
getDataColumns(Configuration) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Return data columns for this input, can only be called after setInput is called.
getDataColumns() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
getDataContainer() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
getDataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 dataLength = 3;
getDataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 dataLength = 3;
getDataLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 dataLength = 3;
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
 
getDataSchema() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
Gets the data schema.
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
getDate() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDateResults
 
getDate(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getDate() - Static method in class org.apache.hive.common.util.HiveVersionInfo
The date that Hive was compiled.
getDate(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getDate(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDate(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDate(int, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDate(String, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDate(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDate(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDate(int, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDate(String, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDateField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthLong
 
getDateField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getDateField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampLong
 
getDateFormat() - Static method in class org.apache.hive.common.util.DateUtils
 
getDateStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DateStatistics dateStatistics = 7;
getDateStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getDateTimeExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get DateExprProcessor.
getDateValue(GenericUDF.DeferredObject[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getDayPartInSec(Calendar) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMonthsBetween
 
getDays() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
getDays() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDateResults
 
getDays() - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
getDaysSinceEpoch() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
getDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getDb() - Method in class org.apache.hadoop.hive.metastore.events.InsertEvent
 
getDb() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
Getter for the name of the Database on which the Metastore operation is done.
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
getDB() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getDbAndTableName(String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getDbCommandParser(String) - Static method in class org.apache.hive.beeline.HiveSchemaHelper
 
getDbCommandParser(String, String, String, String, HiveConf) - Static method in class org.apache.hive.beeline.HiveSchemaHelper
 
getDbConn(int) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Get a connection to the database
getDbLocation(Database) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterPartitionEvent
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.events.PreLoadPartitionDoneEvent
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Getter for name of the DB.
getDbName() - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Getter for the name of the DB.
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
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.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
 
getDbName() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getDbName() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec
Getter for DBName of this HCatPartitionSpec.
getDbName() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the db name.
getDbName() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getDBPrivilege(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDBPrivilegeSet(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDBPrivilegeSet(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
getDbTableName(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getDbTableNamePair(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDbTime(Connection) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Determine the current time, using the RDBMS as a source of truth
getDDLFromFieldSchema(String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to Thrift DDL.
getDecimal(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getDecimal(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getDecimalDigits() - Method in class org.apache.hive.service.cli.TypeDescriptor
The number of fractional digits for this type.
getDecimalHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getDecimalHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getDecimalLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getDecimalLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getDecimalPlaces() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
getDecimalStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
getDecimalStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getDecimalTypeForPrimitiveCategories(PrimitiveTypeInfo, PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
getDecimalTypeForPrimitiveCategory(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
getDecimalTypeInfo(int, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getDecimalTypeTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getDeclaredNonStaticFields(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get all the declared non-static fields of Class c.
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 enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
getDefault() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getDefaultArgOI() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getDefaultBlockSize(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getDefaultBlockSize(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getDefaultBlockSize(FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get the default block size for the path.
getDefaultBlockSize(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
getDefaultCost() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel
 
getDefaultCost() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel
 
getDefaultCost() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel
 
getDefaultDatabasePath(String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getDefaultDestDir(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getDefaultDirName() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getDefaultExpr() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
getDefaultExprProcessor() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory
Factory method to get DefaultExprProcessor.
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() - 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
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getDefaultInstance() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
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
 
getDefaultParallelism() - Method in interface org.apache.hadoop.hive.ql.exec.spark.HiveSparkClient
For standalone mode, this can be used to get total number of cores.
getDefaultParallelism() - Method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
getDefaultParallelism() - Method in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
getDefaultParallelism() - Method in interface org.apache.hive.spark.client.SparkClient
Get default parallelism.
getDefaultPartitionName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
getDefaultPartitionName() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getDefaultPrecision(SqlTypeName) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
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.ConstantPropagateProcFactory
Factory method to get the ConstantPropagateDefaultProc 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.optimizer.spark.SparkSkewJoinProcFactory
 
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
 
getDefaultRealm() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
getDefaultRealm() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
getDefaultRealm() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.KerberosNameShim
 
getDefaultReplication(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getDefaultReplication(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getDefaultReplication(FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get the default replication for a path.
getDefaultReplication(FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
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.
getDefaultTraitSet(RelOptCluster) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.TraitsUtil
 
getDefaultTransactionIsolation() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDefaultValue() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
getDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
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.metastore.model.MIndex
 
getDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getDelegates() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
getDelegates() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
getDelegates() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
getDelegates() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getDelegates() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
getDelegates() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
getDelegates() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
getDelegationToken(Connector) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Obtain a DelegationToken from Accumulo in a backwards compatible manner.
getDelegationToken(String, String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Get a new delegation token.
getDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDelegationToken(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDelegationToken(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
This is expected to be a no-op when in local mode, which means that the implementation will return null.
getDelegationToken(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
 
getDelegationToken(String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getDelegationToken(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets the delegation token.
getDelegationToken(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getDelegationToken(JobId) - Method in class org.apache.hive.hcatalog.templeton.tool.DelegationTokenCache
 
getDelegationToken(String, String) - Method in class org.apache.hive.jdbc.HiveConnection
 
getDelegationToken(String, String) - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getDelegationToken(SessionHandle, HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.CLIService
 
getDelegationToken(SessionHandle, HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.CLIServiceClient
 
getDelegationToken(SessionHandle, HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getDelegationToken(SessionHandle, HiveAuthFactory, String, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
getDelegationToken(HiveAuthFactory, String, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
getDelegationToken(HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getDelegationToken() - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
getDelegationToken(HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
getDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
GetDelegationToken(TGetDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.GetDelegationToken_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetDelegationToken(TGetDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.GetDelegationToken_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetDelegationToken(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetDelegationToken(TGetDelegationTokenReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
getDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
GetDelegationToken(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getDelegationToken(SessionHandle, HiveAuthFactory, String, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
getDelegationTokenFromMetaStore(String) - Method in class org.apache.hive.service.cli.CLIService
 
getDelegationTokenWithService(String, String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getDeleteAggr(String, String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares DELETE statement for cleanup.
getDeleteData() - Method in class org.apache.hadoop.hive.metastore.events.DropPartitionEvent
 
getDeleteData() - Method in class org.apache.hadoop.hive.metastore.events.DropTableEvent
 
getDeleteData() - Method in class org.apache.hadoop.hive.metastore.events.PreDropPartitionEvent
 
getDeleteData() - Method in class org.apache.hadoop.hive.metastore.events.PreDropTableEvent
 
getDelimiter() - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
getDelimiter() - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Get the SQL statement delimiter
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.SparkWork
 
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
 
getDescription() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
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.CastStringToIntervalDayTime
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CharScalarConcatStringGroupCol
 
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.gen.CastDateToBooleanViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CharScalarNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColGreaterEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColLessEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColNotEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarGreaterEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarLessEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarNotEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarAddDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarDivideDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarModuloDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarMultiplyDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarSubtractDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharScalarNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColGreaterEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColLessEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateColNotEqualDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarGreaterEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarLessEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDateScalarNotEqualDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColGreaterIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColLessIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarLessIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColGreaterIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColLessIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarLessIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringScalarNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColGreaterTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColLessTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampColNotEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterTimestampScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharScalarNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColNotEqualIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColNotEqualIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarNotEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualDoubleScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarNotEqualTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalDayTimeColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractTimestampColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessEqualStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarNotEqualStringGroupColumn
 
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.IfExprCharScalarStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprCharScalarStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
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.IfExprStringScalarVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringGroupColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringScalar
 
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.StringGroupColConcatCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatVarCharScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
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.StringScalarConcatStringGroupCol
 
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.VarCharScalarConcatStringGroupCol
 
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.VectorElt
 
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.VectorUDFDateLong
 
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
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getDescriptor() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getDescriptor() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getDescriptor() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getDescriptor() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
getDescriptorForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
getDescTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDeserializer(Configuration, Table, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
getDeserializer Get the Deserializer for a table.
getDeserializer(Configuration, Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
getDeserializer Get the Deserializer for a partition.
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDeserializer(boolean) - 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
 
getDeserializer(Configuration) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
Return a deserializer object corresponding to the tableDesc.
getDeserializer(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getDeserializer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
getDeserializer(String, String) - Static method in class org.apache.hive.hcatalog.messaging.MessageFactory
Getter for MessageDeserializer, corresponding to the specified format and version.
getDeserializer() - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
 
getDeserializerClass(Configuration, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getDeserializerClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDeserializerClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getDeserializerClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getDeserializerFromMetaStore(boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDest_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
getDest_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
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
 
getDiagnostic() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getDiagnostics() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
 
getDictionarySize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional uint32 dictionarySize = 2;
getDictionarySize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
optional uint32 dictionarySize = 2;
getDictionarySize() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncodingOrBuilder
optional uint32 dictionarySize = 2;
getDigitsArray(int[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Similar to UnsignedInt128.toFormalString() but returns an array of digits instead of string.
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
 
getDirectDecompressor(HadoopShims.DirectCompressionType) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getDirectDecompressor(HadoopShims.DirectCompressionType) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getDirectDecompressor(HadoopShims.DirectCompressionType) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
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
 
getDirectoryDesc() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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
 
getDisplayName() - Method in class org.apache.hive.spark.counter.SparkCounter
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.contrib.genericudf.example.GenericUDFDBOutput
 
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.GenericUDFAddMonths
 
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.GenericUDFBaseBinary
 
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.GenericUDFCbrt
 
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.GenericUDFCurrentDate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
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.GenericUDFDateFormat
 
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.GenericUDFFactorial
 
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.GenericUDFGreatest
 
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.GenericUDFInitCap
 
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.GenericUDFLastDay
 
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.GenericUDFLevenshtein
 
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.GenericUDFMonthsBetween
 
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.GenericUDFNextDay
 
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.GenericUDFSoundex
 
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.GenericUDFToIntervalDayTime
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToIntervalYearMonth
 
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.GenericUDFTrunc
 
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, ImmutableBitSet, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistinctRowCount
 
getDistinctRowCount(RelNode, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistinctRowCount
 
getDistinctRowCount(Join, ImmutableBitSet, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.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.
getDistribution(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getDistribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getDistribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getDistribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getDistribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getDistribution(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getDistribution() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getDistribution() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
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
 
getDnsPath(Path, Configuration) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Hadoop File System reverse lookups paths with raw ip addresses The File System URI always contains the canonical DNS name of the Namenode.
getDnsPath(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getDoAsEnabled() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
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.exec.spark.SparkMapRecordHandler
 
getDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
getDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
getDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
getDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getDoneJoins() - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
getDoSplitsGrouping() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getDotName(String[]) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDouble() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getDouble(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the double value out of a primitive object.
getDouble(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getDouble(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDouble(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getDouble(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDouble(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getDoubleHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getDoubleHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getDoubleLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getDoubleLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getDoubleStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
getDoubleStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getDoubleVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getDoubleVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
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
 
getDoubleValue(GenericUDF.DeferredObject[], int, ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getDoubleValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
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.FileMergeDesc
 
getDPCtx() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getDpSortState() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getDriverMajorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDriverMinorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDriverName() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDriverVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getDropDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDropDatabaseMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getDropDatabaseMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize DropDatabaseMessage instance.
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
 
getDropPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getDropPartitionMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize DropPartitionMessage instance.
getDroppedColumns() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getDropTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getDropTableMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to de-serialize DropTableMessage instance.
getDropTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AddPartitionReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterPartitionReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterTableReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.CreateTableReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropDatabaseReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropPartitionReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropTableReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.InsertReplicationTask
 
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.NoopReplicationTask
Returns a list of commands to send to a hive driver on the dest warehouse
getDstWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Returns a Iterable to send to a hive driver on the source warehouse If you *need* a List instead, you can use guava's ImmutableList.copyOf(iterable) or Lists.newArrayList(iterable) to get the underlying list, but this defeats the purpose of making this interface an Iterable rather than a List, since it is very likely that the number of Commands returned here will cause your process to run OOM.
getDummyOps() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getDummyOps() - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
getDummyOpsMap() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
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
 
getDummyTableScan() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getDumpFilePrefix() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getDumpFilePrefix() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getDuration(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getDynamicPartitioningKeys() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getDynOutPaths(List<String>, String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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(ReduceSinkOperator, ReduceWork) - Static method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
getEdgeProperty(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
returns the edge type connecting work a and b
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.SparkEdgeProperty
 
getEdgeType() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getEdgeType(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.abort_txn
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_dynamic_partitions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_index
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_pspec
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_req
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_database
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_function
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_index
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partitions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_cascade
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.cancel_delegation_token
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.check_lock
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.commit_txn
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.compact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_database
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_function
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_type
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_partition_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_table_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_database
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_function
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_index_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partitions_req
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_type
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.exchange_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.fire_listener_event
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_aggr_stats_for
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_databases
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_tables
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_config_value
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_current_notificationEventId
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_database
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_databases
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_delegation_token
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_function
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_functions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_names
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_indexes
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_next_notification
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns_info
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_part_specs_by_filter
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names_ps
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_with_auth
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_expr
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_filter
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_names
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps_with_auth
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_pspec
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_statistics_req
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_with_auth
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_principals_in_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_privilege_set
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_grants_for_principal
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_names
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema_with_environment_context
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_names_by_filter
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_objects_by_name
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_statistics_req
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_tables
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type_all
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.getMetaConf
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_privileges
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_privileges
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat_txn_range
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.isPartitionMarkedForEvent
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_privileges
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_roles
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.lock
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.markPartitionForEvent
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.open_txns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_has_valid_characters
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_spec
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_vals
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.rename_partition
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.renew_delegation_token
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_privileges
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_role
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_aggr_stats_for
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_ugi
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.setMetaConf
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_compact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_locks
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.unlock
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_partition_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_table_column_statistics
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.clean
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.execute
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchAll
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchN
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchOne
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getClusterStatus
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getQueryPlan
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getSchema
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getThriftSchema
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelOperation
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseOperation
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseSession
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.ExecuteStatement
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.FetchResults
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetCatalogs
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetColumns
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetFunctions
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetInfo
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetOperationStatus
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetResultSetMetadata
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetSchemas
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTables
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTableTypes
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTypeInfo
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.OpenSession
 
getEmptyArgsInstance() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.RenewDelegationToken
 
getEmptyTable(String, String) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
Initialize an empty table.
getEnclosingWork(Operator<?>, GenTezProcContext) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
getEncosingWork finds the BaseWork any given operator belongs to.
getEncoding() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
The manner in which the value is encoded in Accumulo
getEnd() - Method in class org.apache.hadoop.hive.common.DiskRange
 
getEnd() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
getEnd() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
getEnd() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
getEndColumn() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getEndLine() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getEndTime(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getEntry(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntry(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
repeated .orc.proto.RowIndexEntry entry = 1;
getEntry(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexOrBuilder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexOrBuilder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexOrBuilder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexOrBuilder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
repeated .orc.proto.RowIndexEntry entry = 1;
getEntryOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexOrBuilder
repeated .orc.proto.RowIndexEntry entry = 1;
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
getEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
getEnvironmentContext() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
getEnvironmentContext() - Method in class org.apache.hadoop.hive.metastore.events.ListenerEvent
 
getEquiJoinPredicateElements() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.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
 
getErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getErrorCode() - Method in enum org.apache.hive.hcatalog.common.ErrorType
Gets the error code.
getErrorCode() - Method in exception org.apache.hive.hcatalog.common.HCatException
Gets the error code.
getErrorCode() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getErrorCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
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
 
getErrorFile() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Currently unused.
getErrorHandler() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
getErrorHeader(RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getErrorMessage() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
getErrorMessage(RecognitionException, String[]) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
getErrorMessage() - Method in enum org.apache.hive.hcatalog.common.ErrorType
Gets the error message.
getErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
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
 
getErrorType() - Method in exception org.apache.hive.hcatalog.common.HCatException
Gets the error type.
getErrRecordReaderClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
getEscapeChar() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
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.
getEvent() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Returns the event that this ReplicationTask is attempting to replicate
getEventCounter() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
 
getEventId() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
getEventId() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getEventId() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getEventId() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getEventId() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
getEventId() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
getEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
getEventScope() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getEventsIterator() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
getEventSourceColumnNameMap() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getEventSourcePartKeyExprMap() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getEventSourceTableDescMap() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getEventsSize() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
getEventTime() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getEventTime() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getEventTime() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getEventType() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getEventType() - Method in class org.apache.hadoop.hive.metastore.events.PreEventContext
 
getEventType() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getEventType() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getEventType() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getException() - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionContext
 
getException() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getExcludeQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getExecContext() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getExecJarPathLocal() - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getExecutorCount() - Method in interface org.apache.hadoop.hive.ql.exec.spark.HiveSparkClient
 
getExecutorCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
getExecutorCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
getExecutorCount() - Method in interface org.apache.hive.spark.client.SparkClient
Get the count of executors.
getExitVal() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
getExitValue() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The system exit value of the job.
getExpected() - Method in class org.apache.hadoop.hive.conf.Validator.StringSet
 
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
 
getExportedKeys(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getExpr() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
getExpr() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
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(Configuration) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
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<? extends ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getExprNode(Integer, RelNode, ExprNodeConverter) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getExprNode() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getExprNode() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getExprNodeColumnDesc(List<ExprNodeDesc>, Map<Integer, ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
getExprNodeColumnDesc(ExprNodeDesc, Map<Integer, ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Get Map of ExprNodeColumnDesc HashCode to ExprNodeColumnDesc.
getExprNodeDesc() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
getExprNodeExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getExprNodes(List<Integer>, RelNode, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getExprs() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
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
 
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.ExprNodeDynamicListDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getExtended() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getExternal() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getExternalTmpPath(Path) - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store tmp data destined for external Path.
getExtraNameCharacters() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getExtTmpPathRelTo(Path) - 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
getFailedTaskCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
getFalseCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.BooleanColumnStatistics
 
getFalsePositiveProbability() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getFamilyName() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getFamilyName() - Static method in class org.apache.hadoop.hive.hbase.HBaseStatsUtils
Returns the family name for stored statistics.
getFamilyNameBytes() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getFamilyPath(Configuration, Properties) - Static method in class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
Retrieve the family path, first check the JobConf, then the table properties.
getFeedSubscribers() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getFetchDirection() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getFetchDirection() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getFetchDirection() - Method in class org.apache.hive.jdbc.HiveStatement
 
getFetchExpr() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
getFetchOperators() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getFetchOrientation(TFetchOrientation) - Static method in enum org.apache.hive.service.cli.FetchOrientation
 
getFetchSink() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchSize() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getFetchSize() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getFetchSize() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getFetchSize() - Method in class org.apache.hive.jdbc.HiveStatement
 
getFetchSource() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchSources(List<Task<?>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger
 
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
 
getFetchType(short) - Static method in enum org.apache.hive.service.cli.FetchType
 
getFetchType() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
getField(int) - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloRow
 
getField(int) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseRow
Get one field out of the HBase row.
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
 
getField(int) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
Get one field out of the struct.
getField(int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
Get one field out of the struct.
getField() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Get the field out of the union.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getField(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
Get one field out of the struct.
getField() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
Get the set field out of the union.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryUnionObjectInspector
Return the field based on the tag value associated with the Object.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
Return the field based on the tag value associated with the Object.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getField(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Return the field based on the tag associated with the Object.
getField(int) - Method in interface org.apache.hadoop.hive.serde2.StructObject
 
getField(TempletonStorage.Type, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
getField(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
getField(TempletonStorage.Type, String, String) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
Get the value of one field for a given data type.
getField(TempletonStorage.Type, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
getField0() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
getField1() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getField2() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getField3() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getField3Iterator() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getField3Size() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getFieldByName(String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
getFieldComment() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
getFieldComment() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
getFieldComment() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
getFieldComment() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.StructField
Get the comment for the field.
getFieldComment() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getFieldDesc(ColumnStatisticsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getFieldDesc(FireEventRequestData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
getFieldDesc(RequestPartsSpec._Fields) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
getFieldDesc(PropValueUnion._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getFieldDesc(TColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getFieldDesc(TColumnValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getFieldDesc(TGetInfoValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getFieldDesc(TTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getFieldDesc(TTypeQualifierValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getFieldID() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
getFieldID() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
getFieldID() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
getFieldID() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.StructField
Get the fieldID for the field.
getFieldID() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
getFieldInited() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
getFieldMap(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
 
getFieldName() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
getFieldName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
getFieldName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
getFieldName() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.StructField
Get the name of the field.
getFieldName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TRow._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
 
getFieldName() - Method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
 
getFieldNames(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
getFieldNames(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated string fieldNames = 3;
getFieldNames(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated string fieldNames = 3;
getFieldNames(List<Integer>, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getFieldNames(StructObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the list of field names as csv from a StructObjectInspector.
getFieldNames() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
getFieldNamesBytes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
getFieldNamesBytes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated string fieldNames = 3;
getFieldNamesBytes(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated string fieldNames = 3;
getFieldNamesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
getFieldNamesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated string fieldNames = 3;
getFieldNamesCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated string fieldNames = 3;
getFieldNamesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
getFieldNamesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated string fieldNames = 3;
getFieldNamesList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated string fieldNames = 3;
getFieldObjectInspector() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
getFieldObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
getFieldObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
getFieldObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.StructField
Get the ObjectInspector for the field.
getFieldObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
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.metastore.api.Type
 
getFields(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getFields(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getFields() - Method in class org.apache.hadoop.hive.metastore.model.MType
 
getFields() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getFields() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getFields() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getFields() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
Users are not allowed to modify the list directly, since HCatSchema maintains internal state.
getFieldsAsList() - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloRow
 
getFieldsAsList() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloCompositeRowId
 
getFieldsAsList() - Method in class org.apache.hadoop.hive.hbase.HBaseCompositeKey
 
getFieldsAsList() - Method in class org.apache.hadoop.hive.hbase.LazyHBaseRow
Get the values of the fields as an ArrayList.
getFieldsAsList() - Method in class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
 
getFieldsAsList() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
Get the values of the fields as an ArrayList.
getFieldsAsList() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
Get the values of the fields as an ArrayList.
getFieldsAsList() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
Get the values of the fields as an ArrayList.
getFieldsAsList() - Method in interface org.apache.hadoop.hive.serde2.StructObject
 
getFieldSchema() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
getFieldSchema(HCatFieldSchema) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getFieldSchemaFromTypeInfo(String, TypeInfo) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert TypeInfo to FieldSchema.
getFieldSchemaList(List<HCatFieldSchema>) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldSchemas(List<HCatFieldSchema>) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
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.
getFieldSchemasIterator() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldSchemasSize() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
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.metastore.MetaStoreUtils
 
getFieldsFromDeserializer(String, Deserializer) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFieldsIterator() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldsSize() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
getFieldType(Class<?>, String) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftObjectInspectorUtils
Returns generic type for a field in a Thrift class.
getFieldTypes(StructObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the list of field type as csv from a StructObjectInspector.
getFieldValidator() - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer
Get an optional validator.
getFieldValue(AbortTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
getFieldValue(AddDynamicPartitions._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getFieldValue(AddPartitionsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
getFieldValue(AddPartitionsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
getFieldValue(AggrStats._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
getFieldValue(AlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getFieldValue(BinaryColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
getFieldValue(BooleanColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
getFieldValue(CheckLockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
getFieldValue(ColumnStatistics._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
getFieldValue(ColumnStatisticsDesc._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
getFieldValue(ColumnStatisticsObj._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
getFieldValue(CommitTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
getFieldValue(CompactionRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getFieldValue(ConfigValSecurityException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
getFieldValue(CurrentNotificationEventId._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
getFieldValue(Database._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getFieldValue(Date._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
getFieldValue(DateColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
getFieldValue(Decimal._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
getFieldValue(DecimalColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
getFieldValue(DoubleColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
getFieldValue(DropPartitionsExpr._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
getFieldValue(DropPartitionsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
getFieldValue(DropPartitionsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
getFieldValue(EnvironmentContext._Fields) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
getFieldValue(FieldSchema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getFieldValue(FireEventRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getFieldValue(FireEventResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
getFieldValue(Function._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getFieldValue(GetOpenTxnsInfoResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
getFieldValue(GetOpenTxnsResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
getFieldValue(GetPrincipalsInRoleRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
getFieldValue(GetPrincipalsInRoleResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
getFieldValue(GetRoleGrantsForPrincipalRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
getFieldValue(GetRoleGrantsForPrincipalResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
getFieldValue(GrantRevokePrivilegeRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
getFieldValue(GrantRevokePrivilegeResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
getFieldValue(GrantRevokeRoleRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getFieldValue(GrantRevokeRoleResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
getFieldValue(HeartbeatRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
getFieldValue(HeartbeatTxnRangeRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
getFieldValue(HeartbeatTxnRangeResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getFieldValue(HiveObjectPrivilege._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getFieldValue(HiveObjectRef._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getFieldValue(Index._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getFieldValue(IndexAlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
getFieldValue(InsertEventRequestData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
getFieldValue(InvalidInputException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
getFieldValue(InvalidObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
getFieldValue(InvalidOperationException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
getFieldValue(InvalidPartitionException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
getFieldValue(LockComponent._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getFieldValue(LockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getFieldValue(LockResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
getFieldValue(LongColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
getFieldValue(MetaException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
getFieldValue(NoSuchLockException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
getFieldValue(NoSuchObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
getFieldValue(NoSuchTxnException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
getFieldValue(NotificationEvent._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getFieldValue(NotificationEventRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
getFieldValue(NotificationEventResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
getFieldValue(OpenTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
getFieldValue(OpenTxnsResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
getFieldValue(Order._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
getFieldValue(Partition._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getFieldValue(PartitionListComposingSpec._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
getFieldValue(PartitionsByExprRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
getFieldValue(PartitionsByExprResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
getFieldValue(PartitionSpec._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getFieldValue(PartitionSpecWithSharedSD._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
getFieldValue(PartitionsStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getFieldValue(PartitionsStatsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
getFieldValue(PartitionWithoutSD._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getFieldValue(PrincipalPrivilegeSet._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getFieldValue(PrivilegeBag._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getFieldValue(PrivilegeGrantInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getFieldValue(ResourceUri._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
getFieldValue(Role._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getFieldValue(RolePrincipalGrant._Fields) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getFieldValue(Schema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldValue(SerDeInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getFieldValue(SetPartitionsStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
getFieldValue(ShowCompactRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
getFieldValue(ShowCompactResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
getFieldValue(ShowCompactResponseElement._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getFieldValue(ShowLocksRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
getFieldValue(ShowLocksResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
getFieldValue(ShowLocksResponseElement._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getFieldValue(SkewedInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getFieldValue(StorageDescriptor._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getFieldValue(StringColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
getFieldValue(Table._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getFieldValue(TableStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
getFieldValue(TableStatsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
getFieldValue(ThriftHiveMetastore.abort_txn_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
getFieldValue(ThriftHiveMetastore.abort_txn_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
getFieldValue(ThriftHiveMetastore.add_dynamic_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
getFieldValue(ThriftHiveMetastore.add_dynamic_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
getFieldValue(ThriftHiveMetastore.add_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getFieldValue(ThriftHiveMetastore.add_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getFieldValue(ThriftHiveMetastore.add_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
getFieldValue(ThriftHiveMetastore.add_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getFieldValue(ThriftHiveMetastore.add_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.add_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.add_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
getFieldValue(ThriftHiveMetastore.add_partitions_pspec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
getFieldValue(ThriftHiveMetastore.add_partitions_pspec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
getFieldValue(ThriftHiveMetastore.add_partitions_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
getFieldValue(ThriftHiveMetastore.add_partitions_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
getFieldValue(ThriftHiveMetastore.add_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
getFieldValue(ThriftHiveMetastore.alter_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getFieldValue(ThriftHiveMetastore.alter_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getFieldValue(ThriftHiveMetastore.alter_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
getFieldValue(ThriftHiveMetastore.alter_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
getFieldValue(ThriftHiveMetastore.alter_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getFieldValue(ThriftHiveMetastore.alter_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getFieldValue(ThriftHiveMetastore.alter_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getFieldValue(ThriftHiveMetastore.alter_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getFieldValue(ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.alter_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getFieldValue(ThriftHiveMetastore.alter_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
getFieldValue(ThriftHiveMetastore.alter_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getFieldValue(ThriftHiveMetastore.alter_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getFieldValue(ThriftHiveMetastore.alter_table_with_cascade_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
getFieldValue(ThriftHiveMetastore.alter_table_with_cascade_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
getFieldValue(ThriftHiveMetastore.alter_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.alter_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.append_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.append_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getFieldValue(ThriftHiveMetastore.append_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.append_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.cancel_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.cancel_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.check_lock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
getFieldValue(ThriftHiveMetastore.check_lock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
getFieldValue(ThriftHiveMetastore.commit_txn_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
getFieldValue(ThriftHiveMetastore.commit_txn_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
getFieldValue(ThriftHiveMetastore.compact_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
getFieldValue(ThriftHiveMetastore.compact_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
getFieldValue(ThriftHiveMetastore.create_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getFieldValue(ThriftHiveMetastore.create_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getFieldValue(ThriftHiveMetastore.create_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
getFieldValue(ThriftHiveMetastore.create_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
getFieldValue(ThriftHiveMetastore.create_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
getFieldValue(ThriftHiveMetastore.create_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
getFieldValue(ThriftHiveMetastore.create_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
getFieldValue(ThriftHiveMetastore.create_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getFieldValue(ThriftHiveMetastore.create_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.create_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.create_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
getFieldValue(ThriftHiveMetastore.create_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getFieldValue(ThriftHiveMetastore.delete_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.delete_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
getFieldValue(ThriftHiveMetastore.delete_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.delete_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
getFieldValue(ThriftHiveMetastore.drop_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
getFieldValue(ThriftHiveMetastore.drop_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getFieldValue(ThriftHiveMetastore.drop_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
getFieldValue(ThriftHiveMetastore.drop_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
getFieldValue(ThriftHiveMetastore.drop_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getFieldValue(ThriftHiveMetastore.drop_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.drop_partitions_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
getFieldValue(ThriftHiveMetastore.drop_partitions_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
getFieldValue(ThriftHiveMetastore.drop_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
getFieldValue(ThriftHiveMetastore.drop_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
getFieldValue(ThriftHiveMetastore.drop_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getFieldValue(ThriftHiveMetastore.drop_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getFieldValue(ThriftHiveMetastore.drop_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.drop_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.drop_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
getFieldValue(ThriftHiveMetastore.drop_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getFieldValue(ThriftHiveMetastore.exchange_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
getFieldValue(ThriftHiveMetastore.exchange_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getFieldValue(ThriftHiveMetastore.fire_listener_event_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
getFieldValue(ThriftHiveMetastore.fire_listener_event_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
getFieldValue(ThriftHiveMetastore.get_aggr_stats_for_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
getFieldValue(ThriftHiveMetastore.get_aggr_stats_for_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
getFieldValue(ThriftHiveMetastore.get_all_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
getFieldValue(ThriftHiveMetastore.get_all_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getFieldValue(ThriftHiveMetastore.get_all_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
getFieldValue(ThriftHiveMetastore.get_all_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getFieldValue(ThriftHiveMetastore.get_config_value_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
getFieldValue(ThriftHiveMetastore.get_config_value_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getFieldValue(ThriftHiveMetastore.get_current_notificationEventId_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
getFieldValue(ThriftHiveMetastore.get_current_notificationEventId_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
getFieldValue(ThriftHiveMetastore.get_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
getFieldValue(ThriftHiveMetastore.get_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getFieldValue(ThriftHiveMetastore.get_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
getFieldValue(ThriftHiveMetastore.get_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.get_fields_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getFieldValue(ThriftHiveMetastore.get_fields_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getFieldValue(ThriftHiveMetastore.get_fields_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.get_fields_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.get_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
getFieldValue(ThriftHiveMetastore.get_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
getFieldValue(ThriftHiveMetastore.get_functions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
getFieldValue(ThriftHiveMetastore.get_functions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
getFieldValue(ThriftHiveMetastore.get_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getFieldValue(ThriftHiveMetastore.get_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
getFieldValue(ThriftHiveMetastore.get_index_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getFieldValue(ThriftHiveMetastore.get_index_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getFieldValue(ThriftHiveMetastore.get_indexes_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getFieldValue(ThriftHiveMetastore.get_indexes_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getFieldValue(ThriftHiveMetastore.get_next_notification_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
getFieldValue(ThriftHiveMetastore.get_next_notification_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
getFieldValue(ThriftHiveMetastore.get_open_txns_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
getFieldValue(ThriftHiveMetastore.get_open_txns_info_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
getFieldValue(ThriftHiveMetastore.get_open_txns_info_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
getFieldValue(ThriftHiveMetastore.get_open_txns_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
getFieldValue(ThriftHiveMetastore.get_part_specs_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
getFieldValue(ThriftHiveMetastore.get_part_specs_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getFieldValue(ThriftHiveMetastore.get_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getFieldValue(ThriftHiveMetastore.get_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.get_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.get_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.get_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getFieldValue(ThriftHiveMetastore.get_partition_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getFieldValue(ThriftHiveMetastore.get_partition_names_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getFieldValue(ThriftHiveMetastore.get_partition_names_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getFieldValue(ThriftHiveMetastore.get_partition_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getFieldValue(ThriftHiveMetastore.get_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getFieldValue(ThriftHiveMetastore.get_partition_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partition_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_expr_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_expr_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_pspec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_pspec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_statistics_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_statistics_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_principals_in_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
getFieldValue(ThriftHiveMetastore.get_principals_in_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
getFieldValue(ThriftHiveMetastore.get_privilege_set_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getFieldValue(ThriftHiveMetastore.get_privilege_set_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getFieldValue(ThriftHiveMetastore.get_role_grants_for_principal_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
getFieldValue(ThriftHiveMetastore.get_role_grants_for_principal_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
getFieldValue(ThriftHiveMetastore.get_role_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
getFieldValue(ThriftHiveMetastore.get_role_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getFieldValue(ThriftHiveMetastore.get_schema_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getFieldValue(ThriftHiveMetastore.get_schema_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getFieldValue(ThriftHiveMetastore.get_schema_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
getFieldValue(ThriftHiveMetastore.get_schema_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getFieldValue(ThriftHiveMetastore.get_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getFieldValue(ThriftHiveMetastore.get_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.get_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getFieldValue(ThriftHiveMetastore.get_table_names_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
getFieldValue(ThriftHiveMetastore.get_table_names_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getFieldValue(ThriftHiveMetastore.get_table_objects_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
getFieldValue(ThriftHiveMetastore.get_table_objects_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getFieldValue(ThriftHiveMetastore.get_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getFieldValue(ThriftHiveMetastore.get_table_statistics_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
getFieldValue(ThriftHiveMetastore.get_table_statistics_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
getFieldValue(ThriftHiveMetastore.get_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getFieldValue(ThriftHiveMetastore.get_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getFieldValue(ThriftHiveMetastore.get_type_all_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
getFieldValue(ThriftHiveMetastore.get_type_all_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getFieldValue(ThriftHiveMetastore.get_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
getFieldValue(ThriftHiveMetastore.get_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getFieldValue(ThriftHiveMetastore.getMetaConf_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
getFieldValue(ThriftHiveMetastore.getMetaConf_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
getFieldValue(ThriftHiveMetastore.grant_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
getFieldValue(ThriftHiveMetastore.grant_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
getFieldValue(ThriftHiveMetastore.grant_revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
getFieldValue(ThriftHiveMetastore.grant_revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
getFieldValue(ThriftHiveMetastore.grant_revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
getFieldValue(ThriftHiveMetastore.grant_revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
getFieldValue(ThriftHiveMetastore.grant_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getFieldValue(ThriftHiveMetastore.grant_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
getFieldValue(ThriftHiveMetastore.heartbeat_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
getFieldValue(ThriftHiveMetastore.heartbeat_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
getFieldValue(ThriftHiveMetastore.heartbeat_txn_range_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
getFieldValue(ThriftHiveMetastore.heartbeat_txn_range_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
getFieldValue(ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getFieldValue(ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getFieldValue(ThriftHiveMetastore.list_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getFieldValue(ThriftHiveMetastore.list_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getFieldValue(ThriftHiveMetastore.list_roles_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getFieldValue(ThriftHiveMetastore.list_roles_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getFieldValue(ThriftHiveMetastore.lock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
getFieldValue(ThriftHiveMetastore.lock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
getFieldValue(ThriftHiveMetastore.markPartitionForEvent_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getFieldValue(ThriftHiveMetastore.markPartitionForEvent_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getFieldValue(ThriftHiveMetastore.open_txns_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
getFieldValue(ThriftHiveMetastore.open_txns_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
getFieldValue(ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
getFieldValue(ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
getFieldValue(ThriftHiveMetastore.partition_name_to_spec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
getFieldValue(ThriftHiveMetastore.partition_name_to_spec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getFieldValue(ThriftHiveMetastore.partition_name_to_vals_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
getFieldValue(ThriftHiveMetastore.partition_name_to_vals_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getFieldValue(ThriftHiveMetastore.rename_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getFieldValue(ThriftHiveMetastore.rename_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
getFieldValue(ThriftHiveMetastore.renew_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.renew_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
getFieldValue(ThriftHiveMetastore.revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
getFieldValue(ThriftHiveMetastore.revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getFieldValue(ThriftHiveMetastore.revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
getFieldValue(ThriftHiveMetastore.set_aggr_stats_for_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
getFieldValue(ThriftHiveMetastore.set_aggr_stats_for_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
getFieldValue(ThriftHiveMetastore.set_ugi_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
getFieldValue(ThriftHiveMetastore.set_ugi_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
getFieldValue(ThriftHiveMetastore.setMetaConf_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
getFieldValue(ThriftHiveMetastore.setMetaConf_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
getFieldValue(ThriftHiveMetastore.show_compact_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
getFieldValue(ThriftHiveMetastore.show_compact_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
getFieldValue(ThriftHiveMetastore.show_locks_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
getFieldValue(ThriftHiveMetastore.show_locks_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
getFieldValue(ThriftHiveMetastore.unlock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
getFieldValue(ThriftHiveMetastore.unlock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
getFieldValue(ThriftHiveMetastore.update_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.update_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
getFieldValue(ThriftHiveMetastore.update_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
getFieldValue(ThriftHiveMetastore.update_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
getFieldValue(TxnAbortedException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
getFieldValue(TxnInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
getFieldValue(TxnOpenException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
getFieldValue(Type._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldValue(UnknownDBException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
getFieldValue(UnknownPartitionException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
getFieldValue(UnknownTableException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
getFieldValue(UnlockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
getFieldValue(Version._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
getFieldValue(Adjacency._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getFieldValue(Graph._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getFieldValue(Operator._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getFieldValue(Query._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getFieldValue(QueryPlan._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getFieldValue(Stage._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getFieldValue(Task._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getFieldValue(InnerStruct._Fields) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
getFieldValue(ThriftTestObj._Fields) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getFieldValue(Complex._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getFieldValue(IntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getFieldValue(MegaStruct._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getFieldValue(MiniStruct._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
getFieldValue(SetIntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
getFieldValue(HiveClusterStatus._Fields) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getFieldValue(HiveServerException._Fields) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getFieldValue(ThriftHive.clean_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
getFieldValue(ThriftHive.clean_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
getFieldValue(ThriftHive.execute_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getFieldValue(ThriftHive.execute_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
getFieldValue(ThriftHive.fetchAll_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
getFieldValue(ThriftHive.fetchAll_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getFieldValue(ThriftHive.fetchN_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
getFieldValue(ThriftHive.fetchN_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getFieldValue(ThriftHive.fetchOne_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
getFieldValue(ThriftHive.fetchOne_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getFieldValue(ThriftHive.getClusterStatus_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
getFieldValue(ThriftHive.getClusterStatus_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getFieldValue(ThriftHive.getQueryPlan_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
getFieldValue(ThriftHive.getQueryPlan_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
getFieldValue(ThriftHive.getSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
getFieldValue(ThriftHive.getSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getFieldValue(ThriftHive.getThriftSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
getFieldValue(ThriftHive.getThriftSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getFieldValue(TArrayTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
getFieldValue(TBinaryColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
getFieldValue(TBoolColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
getFieldValue(TBoolValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
getFieldValue(TByteColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
getFieldValue(TByteValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
getFieldValue(TCancelDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
getFieldValue(TCancelDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
getFieldValue(TCancelOperationReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
getFieldValue(TCancelOperationResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
getFieldValue(TCLIService.CancelDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
getFieldValue(TCLIService.CancelDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
getFieldValue(TCLIService.CancelOperation_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
getFieldValue(TCLIService.CancelOperation_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
getFieldValue(TCLIService.CloseOperation_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
getFieldValue(TCLIService.CloseOperation_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
getFieldValue(TCLIService.CloseSession_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
getFieldValue(TCLIService.CloseSession_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
getFieldValue(TCLIService.ExecuteStatement_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
getFieldValue(TCLIService.ExecuteStatement_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
getFieldValue(TCLIService.FetchResults_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
getFieldValue(TCLIService.FetchResults_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
getFieldValue(TCLIService.GetCatalogs_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
getFieldValue(TCLIService.GetCatalogs_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
getFieldValue(TCLIService.GetColumns_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
getFieldValue(TCLIService.GetColumns_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
getFieldValue(TCLIService.GetDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
getFieldValue(TCLIService.GetDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
getFieldValue(TCLIService.GetFunctions_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
getFieldValue(TCLIService.GetFunctions_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
getFieldValue(TCLIService.GetInfo_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
getFieldValue(TCLIService.GetInfo_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
getFieldValue(TCLIService.GetOperationStatus_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
getFieldValue(TCLIService.GetOperationStatus_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
getFieldValue(TCLIService.GetResultSetMetadata_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
getFieldValue(TCLIService.GetResultSetMetadata_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
getFieldValue(TCLIService.GetSchemas_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
getFieldValue(TCLIService.GetSchemas_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
getFieldValue(TCLIService.GetTables_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
getFieldValue(TCLIService.GetTables_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
getFieldValue(TCLIService.GetTableTypes_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
getFieldValue(TCLIService.GetTableTypes_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
getFieldValue(TCLIService.GetTypeInfo_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
getFieldValue(TCLIService.GetTypeInfo_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
getFieldValue(TCLIService.OpenSession_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
getFieldValue(TCLIService.OpenSession_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
getFieldValue(TCLIService.RenewDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
getFieldValue(TCLIService.RenewDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
getFieldValue(TCloseOperationReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
getFieldValue(TCloseOperationResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
getFieldValue(TCloseSessionReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
getFieldValue(TCloseSessionResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
getFieldValue(TColumnDesc._Fields) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
getFieldValue(TDoubleColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
getFieldValue(TDoubleValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
getFieldValue(TExecuteStatementReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
getFieldValue(TExecuteStatementResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
getFieldValue(TFetchResultsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
getFieldValue(TFetchResultsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
getFieldValue(TGetCatalogsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
getFieldValue(TGetCatalogsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
getFieldValue(TGetColumnsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getFieldValue(TGetColumnsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
getFieldValue(TGetDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
getFieldValue(TGetDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
getFieldValue(TGetFunctionsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
getFieldValue(TGetFunctionsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
getFieldValue(TGetInfoReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
getFieldValue(TGetInfoResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
getFieldValue(TGetOperationStatusReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
getFieldValue(TGetOperationStatusResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getFieldValue(TGetResultSetMetadataReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
getFieldValue(TGetResultSetMetadataResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
getFieldValue(TGetSchemasReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
getFieldValue(TGetSchemasResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
getFieldValue(TGetTablesReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getFieldValue(TGetTablesResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
getFieldValue(TGetTableTypesReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
getFieldValue(TGetTableTypesResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
getFieldValue(TGetTypeInfoReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
getFieldValue(TGetTypeInfoResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
getFieldValue(THandleIdentifier._Fields) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
getFieldValue(TI16Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
getFieldValue(TI16Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
getFieldValue(TI32Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
getFieldValue(TI32Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
getFieldValue(TI64Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
getFieldValue(TI64Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
getFieldValue(TMapTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
getFieldValue(TOpenSessionReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getFieldValue(TOpenSessionResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getFieldValue(TOperationHandle._Fields) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
getFieldValue(TPrimitiveTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
getFieldValue(TRenewDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
getFieldValue(TRenewDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
getFieldValue(TRow._Fields) - Method in class org.apache.hive.service.cli.thrift.TRow
 
getFieldValue(TRowSet._Fields) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getFieldValue(TSessionHandle._Fields) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
getFieldValue(TStatus._Fields) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getFieldValue(TStringColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
getFieldValue(TStringValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
getFieldValue(TStructTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
getFieldValue(TTableSchema._Fields) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
getFieldValue(TTypeDesc._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
getFieldValue(TTypeQualifiers._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
getFieldValue(TUnionTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
getFieldValue(TUserDefinedTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.hive.shims.HiveHarFileSystem
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getFileExtension(JobConf, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
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.
getFileFormat() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getFileFromClasspath(String) - Static method in class org.apache.hive.common.util.HiveTestUtils
 
getFileId() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getFileMetaInfo() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getFileNameFromDirName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getFiles() - Method in class org.apache.hadoop.hive.metastore.events.InsertEvent
Get list of files created as a result of this DML operation
getFiles() - Method in class org.apache.hive.hcatalog.messaging.InsertMessage
Get the list of files created as a result of this DML operation.
getFiles() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getFilesAdded() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
getFilesAddedIterator() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
getFilesAddedSize() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
getFileSchema() - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
getFileSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
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
getFileStatus(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getFileStatus() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.Hadoop20SFileStatus
 
getFileStatus() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.Hadoop23FileStatus
 
getFileStatus() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsFileStatus
 
getFileStatusesForLocation(String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getFileStatusesForSD(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getFileStatusesForUnpartitionedTable(Database, Table) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getFileStatusOrNull(FileSystem, Path) - Static method in class org.apache.hadoop.hive.common.FileUtils
Attempts to get file status.
getFileStatusRecurse(Path, int, FileSystem) - Static method in class org.apache.hadoop.hive.common.HiveStatsUtils
Get all file status from a root path and recursively go deep into certain levels.
getFilesystem() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getFileSystem() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniDFSShim
 
getFileSystem() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniDFSShim
 
getFileSystem() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
getFileVersion() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the file format version.
getFileVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getFiltedBlocks() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
getFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
getFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
getFilter() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
getFilter() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
getFilter() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Gets the value of partition filter
getFilteredValue(byte, Object) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
 
getFilterObject() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
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.ConstantPropagateProcFactory
Factory method to get the ConstantPropagateFilterProc 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.
getFilterString() - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity
 
getFilterTag(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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.
getFirst() - Method in class org.apache.hadoop.hive.common.ObjectPair
 
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.
getFlag() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getFlattenedColumnsCount(ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcUtils
Returns the number of columns after flatting complex types.
getFloat(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the float value out of a primitive object.
getFloat(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getFloat(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getFloat(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getFloat(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getFloat(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getFloatVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getFloatVar(Configuration, HiveConf.ConfVars, float) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getFloatVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getFnName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
getFoldedFromCol() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getFoldedFromVal() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getFooterCount(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get footer line count for a table.
getFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 footerLength = 1;
getFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 footerLength = 1;
getFooterLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 footerLength = 1;
getFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 footerLength = 4;
getFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 footerLength = 4;
getFooterLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 footerLength = 4;
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
 
getForHiveCommandInternal(String[], HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
getFormattedTimeWithDiff(DateFormat, long, long) - Static method in class org.apache.hive.common.util.HiveStringUtils
Formats time in ms and appends difference (finishTime - startTime) as returned by formatTimeDiff().
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
 
getFromMapping(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
getFromPath() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
getFromPool() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool
 
getFs(Path, Configuration) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Helper functions to convert IOException to MetaException
getFs(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getFsAction(Privilege) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
Given a privilege, return what FsActions are required
getFsActions(Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
Given a Privilege[], find out what all FsActions are required
getFullDDLFromFieldSchema(String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to Thrift DDL + column names and column types
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.
getFullFileStatus(Configuration, FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getFullFileStatus(Configuration, FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getFullFileStatus(Configuration, FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
For a given file, return a file status
getFullName() - Method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay.DayOfWeek
 
getFullPartitionName() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
getFullPercent() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getFullTableName() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
getFullyQualifiedTableName(String, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
 
getFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
getFunc() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getFuncDef() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getFuncDefExplain() - 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
 
getFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
getFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
getFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAddMonths
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCbrt
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateFormat
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFactorial
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFGreatest
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInitCap
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLastDay
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeast
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLevenshtein
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMonthsBetween
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay
 
getFuncName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSoundex
 
getFuncText() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getFunction(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getFunction(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getFunction(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getFunction(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Retrieve function by name.
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 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
 
getFunctionColumns(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getFunctionInfo(String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Looks up the function name in the registry.
getFunctionName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getFunctionName() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
getFunctionName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
getFunctionNames() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getFunctionNames(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getFunctionNames(String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
getFunctionNames(Pattern) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Returns a set of registered function names.
getFunctionNamesByLikePattern(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns a set of registered function names which matchs the given pattern.
getFunctions(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getFunctions(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getFunctions(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getFunctions(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Retrieve list of function names based on name pattern.
getFunctions(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFunctions(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getFunctions(SessionHandle, String, String, String) - Method in class org.apache.hive.service.cli.CLIService
 
getFunctions(SessionHandle, String, String, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getFunctions(SessionHandle, String, String, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
getFunctions(String, String, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
getFunctions operation handler
getFunctions(String, String, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetFunctions(TGetFunctionsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetFunctions_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetFunctions(TGetFunctionsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetFunctions_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetFunctions(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetFunctions(TGetFunctionsReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetFunctions(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getFunctions(SessionHandle, String, String, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
GetFunctionsOperation - Class in org.apache.hive.service.cli.operation
GetFunctionsOperation.
GetFunctionsOperation(HiveSession, String, String, String) - Constructor for class org.apache.hive.service.cli.operation.GetFunctionsOperation
 
getFunctionSynonyms(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns the set of synonyms of the supplied function.
getFunctionSynonyms(String, FunctionInfo, Set<String>) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Adds to the set of synonyms of the supplied function.
getFunctionText(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getFunctionType() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getFunctionType() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getfWork() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getGeneratedKeys() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getGeneratedKeys() - Method in class org.apache.hive.jdbc.HiveStatement
 
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(String, List<ObjectInspector>, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Get the GenericUDAF evaluator for the name and argumentClasses.
getGenericUDAFEvaluator(String, ArrayList<ExprNodeDesc>, ASTNode, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Returns the GenericUDAFEvaluator for the aggregation.
getGenericUDAFEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFEvaluatorClassName() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFInfo(GenericUDAFEvaluator, GenericUDAFEvaluator.Mode, ArrayList<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Returns the GenericUDAFInfo struct for the aggregation.
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
 
getGenericUDAFResolver(String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
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
 
getGenericWindowingEvaluator(String, List<ObjectInspector>, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
getGenJoinKeys() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getGetInfoType(TGetInfoType) - Static method in enum org.apache.hive.service.cli.GetInfoType
 
getGlobalLimit() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
getGlobalLimitCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
getGrant() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
getGrantorName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getGrantorPrincipal() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getGrantorPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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.metastore.api.RolePrincipalGrant
 
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
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
getGroupByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getGroupByMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupByOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
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.ConstantPropagateProcFactory
Factory method to get the ConstantPropagateGroupByProc 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
 
getGroupDisplayName() - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
getGroupGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getGroupingSetPosition() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupingSets(List<ASTNode>, QBParseInfo, String) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getGroupingSetsForCube(int) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getGroupingSetsForRollup(int) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getGroupKeyObject() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getGroupName() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticGroup
 
getGroupName() - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
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
 
getGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getGroupPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getGroups() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
getGuid() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
getHadoopConfDir() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
getHadoopConfNames() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getHadoopConfNames() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getHadoopConfNames() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getHadoopSaslProperties(Configuration) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
Read and return Hadoop SASL configuration which can be configured using "hadoop.rpc.protection"
getHadoopSaslProperties(Configuration) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge23
Read and return Hadoop SASL configuration which can be configured using "hadoop.rpc.protection"
getHadoopShims() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Factory method to get an instance of HadoopShims based on the version of Hadoop on the classpath.
getHadoopSupportsSplittable() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getHadoopThriftAuthBridge() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
 
getHadoopToken(AuthenticationToken) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
 
getHadoopVersion() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getHandle() - Method in class org.apache.hive.service.cli.operation.Operation
 
getHandled() - Method in class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
getHandleIdentifier() - Method in class org.apache.hive.service.cli.Handle
 
getHandler() - Method in class org.apache.hadoop.hive.metastore.events.ListenerEvent
 
getHandler() - Method in class org.apache.hadoop.hive.metastore.events.PreEventContext
 
getHandlerChain() - Method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
 
getHandlerClsName() - Method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
 
getHandleResult() - Method in class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
getHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getHarRequested() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Returns whether or not hadoop archiving has been requested for this job
getHarUri(URI) - Method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.HarPathHelper
 
getHasGroupBy() - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc.SparkMapJoinFollowedByGroupByProcessor
 
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
getHashFromKey() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
getHashFromKey() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.KeyValueHelper
Get hash value from the key.
getHashMapFromDisk(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
getHashMapFromMemory() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
getHashPartitions() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getHashTableLoader(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getHashTableLoader(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
This override lets us substitute our own fast vectorized hash table loader.
getHashtableMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getHashTableMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getHasNull() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional bool hasNull = 10;
getHasNull() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional bool hasNull = 10;
getHasNull() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional bool hasNull = 10;
getHasVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
returns True if any of the aggregators has a variable size
getHavingClauseSubQueryPredicate() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getHavingForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getHBaseSerdeParam() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
getHCatEventMessage(String, String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to construct HCatEventMessage from string.
getHCatFieldSchema(FieldSchema) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
Convert a HCatFieldSchema to a FieldSchema
getHCatFieldSchemaList(FieldSchema...) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getHCatFieldSchemaList(List<FieldSchema>) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getHCatReader(ReadEntity, Map<String, String>) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should be called once from master node to obtain an instance of HCatReader.
getHCatReader(ReaderContext, int) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should only be called once from every slave node to obtain an instance of HCatReader.
getHCatReader(ReaderContext, int, StateProvider) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should only be called once from every slave node to obtain an instance of HCatReader.
getHCatRecordObjectInspector(StructTypeInfo) - Static method in class org.apache.hive.hcatalog.data.HCatRecordObjectInspectorFactory
Returns HCatRecordObjectInspector given a StructTypeInfo type definition for the record to look into
getHCatSchema(Schema) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getHCatSchema(List<? extends FieldSchema>) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getHCatSchema(TypeInfo) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getHCatSchema(String) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getHCatSchemaFromTypeString(String) - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getHcatServiceStr() - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
The token to pass to hcat.
getHCatShim() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getHCatShim() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getHCatShim() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getHCatTable() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Getter for underlying HCatTable instance.
getHCatWriter(WriteEntity, Map<String, String>) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should be called at master node to obtain an instance of HCatWriter.
getHCatWriter(WriterContext) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should be called at slave nodes to obtain an instance of HCatWriter.
getHCatWriter(WriterContext, StateProvider) - Static method in class org.apache.hive.hcatalog.data.transfer.DataTransferFactory
This should be called at slave nodes to obtain an instance of HCatWriter.
getHdfsEncryptionShim() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHdfsScratchDirURIString() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHDFSSessionPath(Configuration) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
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.
getHeaderLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 headerLength = 1;
getHeaderLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 headerLength = 1;
getHeaderLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 headerLength = 1;
getHelpText() - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
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
getHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
getHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
getHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
getHighValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
getHighWatermark() - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
getHighWatermark() - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Get the largest committed transaction id.
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
 
getHistoryViewer() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getHitRatio() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getHive() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getHive() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getHiveChar() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
getHiveChar() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
getHiveChar(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getHiveClient(HiveConf) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Deprecated.
getHiveColumnNames() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getHiveColumnTypes() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getHiveConf() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getHiveConf() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getHiveConf() - Method in class org.apache.hive.beeline.HiveSchemaTool
 
getHiveConf(Configuration) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getHiveConf() - Method in class org.apache.hive.service.AbstractService
 
getHiveConf() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getHiveConf() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getHiveConf() - Method in class org.apache.hive.service.FilterService
 
getHiveConf() - Method in interface org.apache.hive.service.Service
Get the configuration of this service.
getHiveConfDir() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getHiveConfs() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getHiveConfVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Helper function to get configuration variables.
getHiveConfVar(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getHiveDb() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getHiveDecimal() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDecimalResults
 
getHiveDecimal() - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
getHiveDecimal(int, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
Get a HiveDecimal instance from the writable and constraint it with maximum precision/scale.
getHiveDecimal(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getHiveDecimalFromByteBuffer(ByteBuffer, int) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getHiveDecimalString() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns the string representation of this value.
getHiveDefaultLocation() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getHiveHistory() - Method in class org.apache.hadoop.hive.ql.session.SessionState
get hiveHistory object which does structured logging.
getHiveInternalColumnName(int) - Method in class org.apache.hive.hcatalog.data.JsonSerDe
 
getHiveIntervalDayTime() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalDayTimeResults
 
getHiveIntervalDayTime() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
getHiveIntervalDayTime(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getHiveIntervalYearMonth() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalYearMonthResults
 
getHiveIntervalYearMonth() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
getHiveIntervalYearMonth(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getHiveIOExceptionHandlerChain(JobConf) - Static method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
 
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
 
getHiveMetastoreClient(HiveConf) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Get or create a hive client depending on whether it exits in cache or not
getHiveObj() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getHiveObjectRef(HiveObjectRef) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getHiveOperation() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHiveOutputFormat(Configuration, TableDesc) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getHiveOutputFormat(Configuration, PartitionDesc) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getHivePrincipal(PrincipalDesc) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getHivePrincipal(String, PrincipalType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getHivePrincipals(List<PrincipalDesc>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getHivePrincipalType(PrincipalType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert thrift principal type to authorization plugin principal type
getHivePrivDbObjects(List<String>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObjectUtils
Convert list of dbnames into list of HivePrivilegeObject
getHivePrivilegeObject(PrivilegeObjectDesc) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
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
getHivePrivileges(List<PrivilegeDesc>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
 
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.
getHiveRoleGrants(IMetaStoreClient, String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getHiveRootDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getHiveSchemaVersion() - Static method in class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
 
getHiveServer2SiteLocation() - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getHiveSiteLocation() - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getHiveTableMD() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getHiveTxnManager() - Method in class org.apache.hadoop.hive.ql.Context
 
getHiveUDF(SqlOperator, RelDataType, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
getHiveVarchar() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
getHiveVarchar() - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
getHiveVarchar(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getHiveVariables() - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
getHiveVariables() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHiveVars() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getHoldability() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getHoldability() - Method in class org.apache.hive.jdbc.HiveConnection
 
getHoldDDLTime() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getHook(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHookLoader
Loads a hook for the specified table.
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
 
getHost() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getHostname() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getHostname() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
getHostname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getHostname() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
getHostName() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
getHostName() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
getHostName() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.KerberosNameShim
 
getHostname() - Static method in class org.apache.hive.common.util.HiveStringUtils
Return hostname without throwing exception.
getHours() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
getHttpUGI() - Method in class org.apache.hive.service.cli.CLIService
 
getI16Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getI16Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getI32Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getI32Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getI32Value() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
getI64Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getI64Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getId() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
getId() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getId() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterVersion
 
getId() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getId() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getId() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getId() - Method in class org.apache.hive.hcatalog.data.transfer.state.DefaultStateProvider
Default implementation.
getId() - Method in interface org.apache.hive.hcatalog.data.transfer.state.StateProvider
This method should return id assigned to slave node.
getId() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
This job id.
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.
getIdentifierQuoteString(Connection) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
Determine the String that should be used to quote identifiers.
getIdentifierQuoteString() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getIds() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
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
 
getIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getIdxProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIfClass() - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
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
 
getIfNotExists() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Gets the if not exists.
getIfNotExists() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Gets the if not exists.
getIfPurge() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getIgnoreProtection() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
GetImage() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getImportedKeys(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getInclude() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getIncludeQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getIndex() - Method in class org.apache.hadoop.hive.metastore.events.AddIndexEvent
 
getIndex() - Method in class org.apache.hadoop.hive.metastore.events.DropIndexEvent
 
getIndex() - Method in class org.apache.hadoop.hive.metastore.events.PreAddIndexEvent
 
getIndex() - Method in class org.apache.hadoop.hive.metastore.events.PreDropIndexEvent
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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, 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.
getIndex(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLag
 
getIndex(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLead
 
getIndex(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getIndexBuilderMapRedTask(Set<ReadEntity>, Set<WriteEntity>, Index, boolean, PartitionDesc, String, PartitionDesc, String, String) - Method in class org.apache.hadoop.hive.ql.index.AggregateIndexHandler
 
getIndexBuilderMapRedTask(Set<ReadEntity>, Set<WriteEntity>, List<FieldSchema>, boolean, PartitionDesc, String, PartitionDesc, String, String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
getIndexBuilderMapRedTask(Set<ReadEntity>, Set<WriteEntity>, List<FieldSchema>, boolean, PartitionDesc, String, PartitionDesc, String, String) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
getIndexBuilderMapRedTask(Set<ReadEntity>, Set<WriteEntity>, Index, boolean, PartitionDesc, String, PartitionDesc, String, String) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
getIndexBuilderMapRedTask(Set<ReadEntity>, Set<WriteEntity>, List<FieldSchema>, boolean, PartitionDesc, String, PartitionDesc, String, String) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
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, int) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getIndexes(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
getIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
getIndexKey() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getIndexKey() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getIndexLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 indexLength = 2;
getIndexLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 indexLength = 2;
getIndexLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 indexLength = 2;
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.metastore.api.Index
 
getIndexName() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
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
 
getIndexPosition(OrcProto.ColumnEncoding.Kind, OrcProto.Type.Kind, OrcProto.Stream.Kind, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils
Get the offset in the index positions for the column that the given stream starts.
getIndexTable() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexTableName(String, String, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getIndexTableName() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
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
 
getInfo(SessionHandle, GetInfoType) - Method in class org.apache.hive.service.cli.CLIService
 
getInfo(SessionHandle, GetInfoType) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getInfo(SessionHandle, GetInfoType) - Method in interface org.apache.hive.service.cli.ICLIService
 
getInfo(GetInfoType) - Method in interface org.apache.hive.service.cli.session.HiveSession
getInfo operation handler
getInfo(GetInfoType) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetInfo(TGetInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetInfo_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetInfo(TGetInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetInfo_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetInfo(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetInfo(TGetInfoReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetInfo(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getInfo(SessionHandle, GetInfoType) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getInfoMessages() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getInfoMessagesIterator() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getInfoMessagesSize() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getInfoStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
GetInfoType - Enum in org.apache.hive.service.cli
GetInfoType.
getInfoType() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
GetInfoValue - Class in org.apache.hive.service.cli
GetInfoValue.
GetInfoValue(String) - Constructor for class org.apache.hive.service.cli.GetInfoValue
 
GetInfoValue(short) - Constructor for class org.apache.hive.service.cli.GetInfoValue
 
GetInfoValue(int) - Constructor for class org.apache.hive.service.cli.GetInfoValue
 
GetInfoValue(long) - Constructor for class org.apache.hive.service.cli.GetInfoValue
 
GetInfoValue(TGetInfoValue) - Constructor for class org.apache.hive.service.cli.GetInfoValue
 
getInfoValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
getInheritTableSpecs() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getInitScript() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
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.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() - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
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.CastStringToIntervalDayTime
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.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
 
getInputColumnIndex(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getInputColumnIndex(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getInputColumnLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
getInputColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
getInputColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorElt
 
getInputColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
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.gen.VectorUDAFAvgDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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
 
getInputFileFormat() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the input file format.
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.metastore.api.StorageDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.io.AvroStorageFormatDescriptor
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.io.ORCFileStorageFormatDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.io.ParquetFileStorageFormatDescriptor
 
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.io.RCFileStorageFormatDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.io.SequenceFileStorageFormatDescriptor
 
getInputFormat() - Method in interface org.apache.hadoop.hive.ql.io.StorageFormatDescriptor
Return the name of the input format as a string
getInputFormat() - Method in class org.apache.hadoop.hive.ql.io.TextFileStorageFormatDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
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
 
getInputFormat() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the input format.
getInputFormat() - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
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.accumulo.AccumuloStorageHandler
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
getInputformatClass() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
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
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getInputFormatClass() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
getInputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getInputFormatClassName() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
 
getInputFormatFromCache(Class, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getInputJobProperties(HiveStorageHandler, InputJobInfo) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getInputName() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
getInputName() - Method in class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
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.orc.OrcFileKeyWrapper
 
getInputPath() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getInputPaths(JobConf, MapWork, Path, Context, boolean) - 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.merge.MergeFileWork
 
getInputPaths() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getInputPathsForPartialScan(TableScanOperator, StringBuffer) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
getInputPathsShim(JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getInputPathsShim(JobConf) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
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
 
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
 
getInputRef(List<Integer>, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getInputRefs(RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getInputRefToCallMap() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
getInputRequiredPrivileges() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getInputRR() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getInputRRList() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinTypeCheckCtx
 
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.parse.spark.OptimizeSparkProcContext
 
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
 
getInputSizePerReducer() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getInputSplit() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
getInputSplit() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getInputSplits() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getInputSplitShim() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getInputSplitShim() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getInputSplitShim() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
getInputStorageHandlerProperties() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the input storage handler properties.
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
 
getInputTableName() - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionContext
 
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.
getInsertData() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
getInsertMessage(String) - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
getInsertMessage(String) - Method in class org.apache.hive.hcatalog.messaging.MessageDeserializer
Method to deserialize InsertMessage
getInspector() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
getInstance() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getInstance() - Static method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
getInstance(Configuration) - Static method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getInstance() - Static method in class org.apache.hadoop.hive.ql.exec.spark.HiveVoidFunction
 
getInstance(SparkConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
getInstance() - Static method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
 
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(HiveConf) - Static method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.CuratorFrameworkSingleton
 
getInstance(ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getInstance(ParseContext, Hive, RewriteCanApplyCtx) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getInstance(List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getInstance(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getInstance() - Static method in class org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry
Singleton instance getter.
getInstance() - Static method in class org.apache.hive.hcatalog.messaging.MessageFactory
Getter for MessageFactory instance.
getInstance() - Static method in class org.apache.hive.hcatalog.templeton.ExecServiceImpl
Retrieve the singleton.
getInstance(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
getInstance(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
getInt(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the integer value out of a primitive object.
getInt(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getInt(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getInt(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getInt(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getIntDayOfWeek(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay
 
getInteger(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getIntegerBitmask() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getIntegerFlag() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
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
 
getInternalList() - Method in class org.apache.hadoop.hive.metastore.model.MStringList
 
getInternalName() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getInternalStorage() - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
getInternalValueOi() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getIntervalDayTimeNanosFromTotalNanos(long) - Static method in class org.apache.hive.common.util.DateUtils
 
getIntervalDayTimeTotalNanos(HiveIntervalDayTime) - Static method in class org.apache.hive.common.util.DateUtils
 
getIntervalDayTimeTotalSecondsFromTotalNanos(long) - Static method in class org.apache.hive.common.util.DateUtils
 
getIntervalExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get IntervalExprProcessor.
getIntsPerElement(int) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Determines the number of ints to store one value.
getIntsPerElement(int) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
Determines the number of ints to store one value.
getIntsPerElement(int) - Static method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Determines the number of ints to store one value.
getIntStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.IntegerStatistics intStatistics = 2;
getIntValue(GenericUDF.DeferredObject[], int, ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getIntValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getIntValue() - Method in class org.apache.hive.service.cli.GetInfoValue
 
getIntVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getIntVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getInvalidTransactions() - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
getInvalidTransactions() - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Get the list of transactions under the high water mark that are not valid.
getInvRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIo() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.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
 
getIpAddress() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getIpAddress() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getIpAddress() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getIpAddress() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getIpAddress() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext
 
getIpAddress() - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getIpAddress() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getIpAddress() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getIpAddress() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
getIsAlterViewAs() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getIsBytesNull(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getIsCascade() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
getIsLikePattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
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
 
getIsolationLevels() - Method in class org.apache.hive.beeline.BeeLine
 
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
 
getItems() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
getItemSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getIteratorPushdown() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getIteratorPushdown() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getIterators(Configuration, ColumnMapper) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
Loop through search conditions and build iterator settings for predicates involving columns other than rowID, if any.
getJar() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getJarFilesByPath(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
get the jar files from specified directory or get jar files by several jar names sperated by comma
getJavaPrimitiveClass() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the associated Java primitive class for this primitive ObjectInspector.
getJavaPrimitiveClass() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Get the Java Primitive class which is the return type of getJavaPrimitiveObject().
getJavaPrimitiveClassFromObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getJc() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getJDBCMajorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getJDBCMinorVersion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getJdbcUriString() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getJdoConnectionUrl(Configuration) - Method in class org.apache.hadoop.hive.contrib.metastore.hooks.SampleURLHook
 
getJdoConnectionUrl(Configuration) - Method in interface org.apache.hadoop.hive.metastore.hooks.JDOConnectionURLHook
Gets the connection URL to supply to JDO.
getJDODatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getJdoOp() - Method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
getJettyShims() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Factory method to get an instance of JettyShims based on the version of Hadoop on the classpath.
getJob() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getJob(String) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.JobConfigurer
Get the Job configuration for a OutputFormat defined by the alias name.
getJobConf() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
getJobConf() - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
Returns JobConf.
getJobConf(JobContext) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getJobConf(JobContext) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getJobConf(JobContext) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get job conf from the old style JobContext.
getJobConfFromContext(JobContext) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getJobContext(String, JobContext) - Static method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
Get the JobContext with the related OutputFormat configuration populated given the alias and the actual JobContext
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.spark.status.impl.LocalSparkJobRef
 
getJobId() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getJobId() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobRef
 
getJobId() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getJobId() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobRef
 
getJobId() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getJobID() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getJobId() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getJobID() - Method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
Get the jobid for this tracking node
getJobIds() - Method in class org.apache.hive.spark.client.MetricsCollection
 
getJobInfo(Configuration) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
Gets the HCatOuputJobInfo object by reading the Configuration and deserializing the string.
getJobInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getJobLauncherHttpAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getJobLauncherHttpAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getJobLauncherHttpAddress(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
All references to jobtracker/resource manager http address in the configuration should be done through this shim
getJobLauncherHttpAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
getJobLauncherRpcAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getJobLauncherRpcAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getJobLauncherRpcAddress(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
All retrieval of jobtracker/resource manager rpc address in the configuration should be done through this shim
getJobLauncherRpcAddress(Configuration) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
getJobMetric(int) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
getJobMetrics(int) - Method in class org.apache.hive.spark.client.MetricsCollection
 
getJobProfile(JobID) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Grab a handle to a job that is already known to the JobTracker.
getJobProfile(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Grab a handle to a job that is already known to the JobTracker.
getJobProfile(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Grab a handle to a job that is already known to the JobTracker.
getJobProperties() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getJobProperties() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the job properties.
getJobs(String, long) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Returns all jobs tagged with the given tag that have been started after the given timestamp.
getJobs(String, long) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Get jobs is only supported on hadoop 2.0+.
getJobs(String, long) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Returns all jobs tagged with the given tag that have been started after the given timestamp.
getJobs(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.JobState
Get an id for each currently existing job, which can be used to create a JobState object.
getJobStatus(JobID) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Grab a handle to a job that is already known to the JobTracker.
getJobStatus(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Grab a handle to a job that is already known to the JobTracker.
getJobStatus(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Grab a handle to a job that is already known to the JobTracker.
getJobTrackerDelegationToken(Configuration, String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getJobTrackerPort() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniMrShim
 
getJobTrackerPort() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniMrShim
 
getJobTrackerPort() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniSparkShim
 
getJobTrackerPort() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniTezShim
 
getJobTrackerPort() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniMrShim
 
getJobTrackerState(ClusterStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getJobTrackerState(ClusterStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getJobTrackerState(ClusterStatus) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Convert the ClusterStatus to its Thrift equivalent: JobTrackerState.
getJobTrackerState(ClusterStatus) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
getJobTrackerURL(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getJoin(RelOptCluster, RelNode, RelNode, RexNode, JoinRelType, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getJoinAlgorithm() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getJoinAliases() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getJoinCollation(HiveCalciteUtil.JoinPredicateInfo, HiveJoin.MapJoinStreamingRelation) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
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
 
getJoinCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel
 
getJoinCount() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
getJoinDistribution(HiveCalciteUtil.JoinPredicateInfo, HiveJoin.MapJoinStreamingRelation) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
getJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getJoinExpressions() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
 
getJoiningCondition() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewrite
 
getJoiningCondition() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewriteNoop
 
getJoinKeyExprs(int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getJoinKeys() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
 
getJoinMemory(HiveJoin) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
getJoinMemory(HiveJoin, HiveJoin.MapJoinStreamingRelation) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
getJoinOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getJoinPredicateInfo() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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.ConstantPropagateProcFactory
 
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.optimizer.spark.SparkSkewJoinProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getJoinPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getJoinRedistribution(HiveCalciteUtil.JoinPredicateInfo) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
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
 
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
 
getJSONString(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
getJSONString(Object, ObjectInspector, String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Use this if you need to have custom representation of top level null .
getJSONValue(Object) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJulianDay() - Method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
getKerberosNameShim(String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
Returns a shim to wrap KerberosName
getKerberosNameShim(String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
Returns a shim to wrap KerberosName
getKerberosNameShim(String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Returns a shim to wrap KerberosName
getKerberosProcessorFactory(HadoopThriftAuthBridge.Server, ThriftCLIService) - Static method in class org.apache.hive.service.auth.KerberosSaslHelper
 
getKerberosServiceTicket(String, String, String, boolean) - Static method in class org.apache.hive.service.auth.HttpAuthUtils
 
getKerberosToken() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
getKerberosTransport(String, String, TTransport, Map<String, String>, boolean) - Static method in class org.apache.hive.service.auth.KerberosSaslHelper
 
getKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
getKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
getKey() - Method in class org.apache.hadoop.hive.metastore.events.ConfigChangeEvent
 
getKey() - Method in class org.apache.hadoop.hive.shims.CombineHiveKey
 
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.orc.OrcFileStripeMergeRecordReader
 
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
 
getKeyColumnMapping() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getKeyContext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
getKeyCountsExplainDesc() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeyDesc() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getKeyEncoding() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
getKeyExpressions() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getKeyExprMap() - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
getKeyFactory() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
getKeyFactory() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getKeyId() - Method in class org.apache.hadoop.hive.metastore.model.MMasterKey
 
getKeyIndex() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
getKeyIndex() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getKeyIndex() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
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
 
getKeyMapping() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
getKeyObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getKeyObjects() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
getKeys() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
getKeys(boolean, String[], JoinOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
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
 
getKeys() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
getKeys() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
 
getKeys() - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
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.JoinDesc
 
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
 
getKeyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getKeyTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
getKeyValues() - Method in class org.apache.hive.hcatalog.messaging.AlterPartitionMessage
 
getKeyValues() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getKeyValueSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getKeywords() - Static method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getKeyWrapper() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapperFactory
 
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
optional .orc.proto.ColumnEncoding.Kind kind = 1;
getKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncodingOrBuilder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional .orc.proto.Stream.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional .orc.proto.Stream.Kind kind = 1;
getKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional .orc.proto.Stream.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional .orc.proto.Type.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional .orc.proto.Type.Kind kind = 1;
getKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional .orc.proto.Type.Kind kind = 1;
getKind() - Method in class org.apache.hadoop.hive.thrift.DelegationTokenIdentifier
 
getLang() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getLastAccessTime() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the last access time.
getLastAccessTime() - Method in class org.apache.hive.service.cli.operation.Operation
 
getLastAccessTime() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getLastAccessTime() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getLastAnalyzed() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
getLastAnalyzed() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getLastAnalyzed() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getLastCommand() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getLastEvent() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
getLastException() - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
getLastheartbeat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getLastInputPath() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getLastReduceLimitDesc() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
getLastReplicationId(HCatDatabase) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Gets the last known replication state of this db.
getLastReplicationId(HCatTable) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Gets the last known replication state of the provided table.
getLastReplicationId(HCatPartition, HCatTable) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Gets the last known replication state of the provided partition.
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
 
getLayout() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
getLazyBinaryListObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
getLazyBinaryMapObjectInspector(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
getLazyBinaryObjectInspectorFromTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Returns the lazy binary object inspector that can be used to inspect an lazy binary object of that typeInfo For primitive types, we use the standard writable object inspector.
getLazyBinaryStructObjectInspector(List<String>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
getLazyBinaryStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
getLazyBinaryUnionObjectInspector(List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
getLazyHiveCharObjectInspector(CharTypeInfo, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyHiveVarcharObjectInspector(VarcharTypeInfo, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyObjectInspector(PrimitiveTypeInfo, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyObjectInspector(PrimitiveTypeInfo, boolean, byte, boolean) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyObjectInspector(PrimitiveTypeInfo, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyObjectInspector(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyParams() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getLazyParams() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getLazyParams() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getLazyParams() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getLazySimpleListObjectInspector(ObjectInspector, byte, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleListObjectInspector(ObjectInspector, byte, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
getLazySimpleMapObjectInspector(ObjectInspector, ObjectInspector, byte, byte, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleMapObjectInspector(ObjectInspector, ObjectInspector, byte, byte, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, Text, boolean, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, Text, boolean, boolean, byte, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, LazyObjectInspectorParameters, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
getLazyStringObjectInspector(boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyTimestampObjectInspector(List<String>) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazyUnionObjectInspector(List<ObjectInspector>, byte, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
Deprecated.
getLazyUnionObjectInspector(List<ObjectInspector>, byte, LazyObjectInspectorParameters) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
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
 
getLeafFilterBuilderByType(PredicateLeaf.Type) - Method in class org.apache.hadoop.hive.ql.io.parquet.LeafFilterFactory
get leaf filter builder by FilterPredicateType, currently date, decimal and timestamp is not supported yet.
getLeafTasks(List<Task<? extends Serializable>>, HashSet<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
Find all leaf tasks of the list of root tasks.
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.SparkWork
getLeaves returns all nodes that do not have a child
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.exec.vector.expressions.gen.FilterCharColumnBetween
 
getLeft() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getLeft() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getLeft() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getLeft() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getLeft() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
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.
getLeftAlias() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getLeftAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getLeftAliases() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getLeftValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getLeftValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getLeftValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getLeftValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getLength() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
getLength() - Method in class org.apache.hadoop.hive.common.DiskRange
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
getLength() - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.exec.tez.DataInputByteBuffer
 
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.OrcProto.Stream.Builder
optional uint64 length = 3;
getLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional uint64 length = 3;
getLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional uint64 length = 3;
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
 
getLength() - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
getLength() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
getLength(ObjectInspector, ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
 
getLength(ObjectInspector, ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
Check if the object is null and return the length of the stream
getLength(ObjectInspector, ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarStruct
 
getLength() - Method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
getLength() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
getLength() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getLength() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
 
getLength() - Method in class org.apache.hive.hcatalog.templeton.tool.NullSplit
 
getLengths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the lengths of the files in the split.
getLenValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getLevel() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getLhs() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
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.ColumnPrunerProcFactory
 
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
 
getLIMProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getLine() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
Deprecated. 
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
 
getLint(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintString(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getList(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getList() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyArray
Returns the List of actual primitive objects.
getList(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getList() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Returns the List of actual primitive objects.
getList(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryListObjectInspector
 
getList(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ListObjectInspector
returns null for data = null.
getList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getList(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getListBucketingCtx() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
getListBucketingCtx() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getListBucketingDepth() - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
getListElement(Object, int) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListElement(Object, int) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getListElement(Object, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryListObjectInspector
 
getListElement(Object, int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ListObjectInspector
returns null for null list, out-of-the-range index.
getListElement(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getListElementObject(int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyArray
Returns the actual primitive object at the index position inside the array represented by this LazyObject.
getListElementObject(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Returns the actual primitive object at the index position inside the array represented by this LazyBinaryObject.
getListElementObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListElementObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getListElementObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ListObjectInspector
 
getListElementObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getListElementTypeInfo() - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
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
 
getListLength() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyArray
Returns -1 for null array.
getListLength(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getListLength() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Returns the array size.
getListLength(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryListObjectInspector
 
getListLength(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ListObjectInspector
returns -1 for data = null.
getListLength(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
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
 
getListSchemaBuilder() - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
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
 
getListTopOps(Operator<? extends OperatorDesc>, List<TableScanOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.SizeBasedBigTableSelectorForAutoSMJ
 
getListType(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getListTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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.
getLiteralPrefix() - Method in enum org.apache.hive.service.cli.Type
Prefix used to quote a literal of this type (may be null)
getLiteralSuffix() - Method in enum org.apache.hive.service.cli.Type
Suffix used to quote a literal of this type (may be null)
getLLFuncExprsInTopExpr(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.parse.LeadLagInfo
 
getLlInfo() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getLlInfoExplain() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getLoadedContainerList() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
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
 
getLocalizedName() - Method in enum org.apache.hive.service.cli.Type
Localized version of type name (may be null).
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.
getLocalSessionPath(Configuration) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getLocalTmpDir() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getLocalTmpDir() - Method in interface org.apache.hive.spark.client.JobContext
Returns a local tmp dir specific to the context
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.metastore.api.StorageDescriptor
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
getLocation() - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Getter for Partition-location.
getLocation() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
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
 
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Deprecated.
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
Gets the location.
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatDatabase
Gets the dB location.
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the location.
getLocation() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the location.
getLocation() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getLocation() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the value of location.
getLocationForExplain() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getLocations() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
getLocations() - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
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
 
getLocations(FileSystem, FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getLocations(FileSystem, FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getLocations(FileSystem, FileStatus) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
For file status returned by listLocatedStatus, convert them into a list of block locations.
getLocations() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
 
getLocations() - Method in class org.apache.hive.hcatalog.templeton.tool.NullSplit
 
getLocationsWithOffset(FileSystem, FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getLocationsWithOffset(FileSystem, FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getLocationsWithOffset(FileSystem, FileStatus) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
For the block locations returned by getLocations() convert them into a Treemap by iterating over the list of blockLocation.
getLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getLocationUri() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getLocationUri() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getLockDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getLockid() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
getLockid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
getLockid() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
getLockid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getLockid() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
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() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
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
 
getLocksIterator() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
getLocksSize() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
getLockTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getLockTime() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getLogDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getLogFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getLoggingLevel(String) - Static method in class org.apache.hadoop.hive.ql.session.OperationLog
 
getLoginTimeout() - Method in class org.apache.hive.jdbc.HiveDataSource
 
getLogRegexes() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getLogWriter() - Method in class org.apache.hive.jdbc.HiveDataSource
 
getLong(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the long value out of a primitive object.
getLong(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getLong(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getLong(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getLong(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getLong(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getLongComparator() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getLongComparator() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getLongComparator() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getLongField(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Fetch an integer field from the store.
getLongHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getLongHighValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getLongLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getLongLowValue() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getLongStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
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
 
getLongValue(GenericUDF.DeferredObject[], int, ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getLongValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getLongValue() - Method in class org.apache.hive.service.cli.GetInfoValue
 
getLongVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getLongVar(Configuration, HiveConf.ConfVars, long) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getLongVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
getLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
getLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
getLowValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
getLString(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getLStringCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLStringList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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
 
getMagic() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
getMagic() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional string magic = 8000;
getMagic() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional string magic = 8000;
getMagicBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
getMagicBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional string magic = 8000;
getMagicBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional string magic = 8000;
getMainWork() - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
getMajor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Get the major version number.
getMajorVersion() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Return the "major" version of Hadoop currently on the classpath.
getMajorVersion() - Method in class org.apache.hive.jdbc.HiveDriver
Returns the major version of this driver.
getMap(String, ColumnEncoding, ColumnEncoding, String, TypeInfo) - Static method in class org.apache.hadoop.hive.accumulo.columns.ColumnMappingFactory
 
getMap() - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
getMap() - Method in class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
 
getMap(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMap() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Return the map object representing this LazyMap.
getMap(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getMap() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Return the map object representing this LazyBinaryMap.
getMap(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryMapObjectInspector
 
getMap(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector
returns null for data = null.
getMap(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getMap(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getMap() - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Get the underlying map.
getMapAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getMapAliases() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getMapAliases() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMapCurrCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getMapEncoding(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
getMapEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getMapJoinBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getMapJoinConversionPos(JoinOperator, OptimizeTezProcContext, int) - Method in class org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin
 
getMapJoinDefault() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getMapJoinDesc(HiveConf, JoinOperator, boolean, String[], List<String>, int, boolean) - 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.
getMapJoinOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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
 
getMapKeyObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getMapKeyObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector
 
getMapKeyObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getMapKeyType() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
Deprecated.
as of 0.13, slated for removal with 0.15 use HCatFieldSchema.getMapKeyTypeInfo() instead
getMapKeyTypeInfo() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getMapKeyTypeInfo() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getMapOfProjIndxToLeafPInfo() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.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.stats.PartialScanWork
 
getMapperClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getMapping() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
getMappingBigFile(String, String) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
Given a small table input file, find the mapping big table input file with the smallest bucket number.
getMappingSpec() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
The property defining how this Column is mapped into Accumulo
getMappingSpec() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getMapProp() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsUpdateWork
 
getMapRedInputFormat(JobConf, Class) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
 
getMapRedLocalWork() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getMapRedStats() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
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.
getMapSchemaBuilder() - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getMapSeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getMapSize() - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
getMapSize() - Method in class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
 
getMapSize(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapSize() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Get the size of the map represented by this LazyMap.
getMapSize(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getMapSize() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Get the size of the map represented by this LazyBinaryMap.
getMapSize(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryMapObjectInspector
 
getMapSize(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector
returns -1 for NULL map.
getMapSize(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getMapType(String, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getMapTypeInfo(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getMapUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getMapValueElement(Object) - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
Get the value in the map for the given key.
getMapValueElement(Object) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
Get the value in the map for the given key.
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
 
getMapValueElement(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Get the value in the map for the key.
getMapValueElement(Object, Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getMapValueElement(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Get the value in the map for the key.
getMapValueElement(Object, Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryMapObjectInspector
 
getMapValueElement(Object, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector
 
getMapValueElement(Object, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getMapValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapValueObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getMapValueObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector
 
getMapValueObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getMapValueSchema() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getMapValueTypeInfo() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkTask
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
getMapWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getMapWorkVectorScratchColumnTypeMap(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMasterKey() - Method in class org.apache.hadoop.hive.metastore.model.MMasterKey
 
getMasterKeys() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getMasterKeys() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getMasterKeys() - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
getMasterKeys() - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Return all master keys.
getMasterKeys() - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
getMasterKeys() - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
getMatchfileObjContainer() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
getMatchfileRowBytesContainer() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
getMax() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
getMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getMax_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
getMaxBinaryLiteralLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxCacheNodes() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getMaxCatalogNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxCharLiteralLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
getMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
getMaxColLen() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getMaxColLen() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getMaxColumnNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
Returns the value of maxColumnNameLength.
getMaxColumnsInGroupBy() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInIndex() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInOrderBy() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInSelect() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInTable() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxConnections() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxCursorNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxDynamicPartitions() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Returns maximum number of allowable dynamic partitions
getMaxEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
getMaxFieldSize() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getMaxFieldSize() - Method in class org.apache.hive.jdbc.HiveStatement
 
getMaxHeapSize() - Static method in class org.apache.hadoop.hive.ql.exec.mapjoin.MapJoinMemoryExhaustionHandler
 
getMaxIfOverflow(long) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
negative number of rows or data sizes are invalid.
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 class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
optional sint32 maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatisticsOrBuilder
optional sint32 maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 maximum = 2;
getMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
optional sint64 maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatisticsOrBuilder
optional sint64 maximum = 2;
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the maximum string.
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.TimestampColumnStatistics
Get the maximum value for the column.
getMaximumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
getMaximumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string maximum = 2;
getMaximumBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string maximum = 2;
getMaximumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
getMaximumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string maximum = 2;
getMaximumBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string maximum = 2;
getMaximumLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 maximumLength = 4;
getMaximumLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 maximumLength = 4;
getMaximumLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 maximumLength = 4;
getMaximumScale() - Method in enum org.apache.hive.service.cli.Type
Maximum scale supported for this type
getMaximumTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMaximumTransactionId() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getMaxIndexLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToCharViaLongToChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToVarChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
 
getMaxLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
 
getMaxLength() - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.TruncStringOutput
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
getMaxLength() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
getMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getMaxMemory() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsConf
 
getMaxNumericPrecision() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
getMaxNumericScale() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
getMaxOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getMaxPartitionsPerNode() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getMaxParts() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
getMaxPartsPerCacheNode() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache
 
getMaxPrecision(SqlTypeName) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
getMaxPrecision() - Method in enum org.apache.hive.service.cli.Type
Maximum precision for numeric types.
getMaxPrefixLength(Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
 
getMaxProcedureNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxReducer() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getMaxReduceTasks() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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.
getMaxRows() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getMaxRows() - Method in class org.apache.hive.jdbc.HiveStatement
 
getMaxRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
getMaxRowSize() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxScale(SqlTypeName) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
getMaxSchemaNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
Returns the maximum size of the batch (number of rows it can hold)
getMaxSplitSize() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsConf
 
getMaxSplitSize() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMaxStatementLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxStatements() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxStatsKeyPrefixLength() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getMaxStatsKeyPrefixLength() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getMaxTableNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxTablesInSelect() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMaxTransaction() - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
getMaxUserNameLength() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getMBeanInfo() - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getMeanTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMechanismName() - Method in class org.apache.hive.service.auth.PlainSaslServer
 
getMechanismNames(Map<String, ?>) - Method in class org.apache.hive.service.auth.PlainSaslServer.SaslPlainServerFactory
 
getMemory(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getMemory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getMemory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getMemory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getMemory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getMemory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getMemory() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getMemoryAndCores() - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
Get Spark shuffle memory per task, and total number of cores.
getMemoryAndCores() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
getMemoryThreshold() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getMemoryThreshold() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMergedCredentials(JobConf) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getMergedCredentials(JobConf) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getMergedCredentials(JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getMergeFilesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getMergeJoinOperator() - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
getMergeLevel() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
getMergeWork(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMergeWork(JobConf, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMergeWorkList(JobConf, String, String, ObjectCache, List<String>) - Method in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
getMessage() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
getMessage() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getMessage() - Method in exception org.apache.hadoop.hive.ql.parse.ParseException
 
getMessage() - Method in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This method has the standard behavior when this object has been created using the standard constructors.
getMessage() - Method in error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getMessage() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getMessage(Message) - Static method in class org.apache.hive.hcatalog.messaging.jms.MessagingUtils
Method to return HCatEventMessage contained in the JMS message.
getMessageBusTopicName(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Retrieve Message-bus topic for a table.
getMessageBusTopicName(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getMessageFormat() - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
getMessageFormat() - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Getter for message-format.
getMetaConf(String) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getMetaConf(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.getMetaConf_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
getMetaConf(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.getMetaConf_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
getMetaConf(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
getMetaConf(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
getMetaConf(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getMetaConf(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getMetaConf(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
get current meta variable
getMetaConf(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getMetaData() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
getMetaData() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinPersistableTableContainer
 
getMetadata(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadata(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadata(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.UserMetadataItem metadata = 5;
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.orc.ReaderImpl
 
getMetadata() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
getMetadata() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedConverterParent
 
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
 
getMetaData() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getMetaData() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getMetaData() - Method in class org.apache.hive.jdbc.HiveConnection
 
getMetaData() - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
getMetaData() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getMetadataBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.UserMetadataItem metadata = 5;
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.
getMetadataKeys() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getMetadataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 metadataLength = 5;
getMetadataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 metadataLength = 5;
getMetadataLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 metadataLength = 5;
getMetadataList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataMethodNames() - Method in class org.apache.hive.beeline.BeeLine
 
getMetadataOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.UserMetadataItem metadata = 5;
getMetadataProvider() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
getMetadataProvider() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveDefaultRelMetadataProvider
 
getMetadataProvider() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
getMetadataValue(String) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get a user metadata value.
getMetadataValue(String) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
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.accumulo.AccumuloStorageHandler
 
getMetaHook() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
getMetaHook() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getMetaHook() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getMetaHook() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
getMetaStoreAuthorizeProviderManagers(Configuration, HiveConf.ConfVars, HiveAuthenticationProvider) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getMetaStoreClient() - Method in interface org.apache.hive.service.cli.session.HiveSession
 
getMetaStoreClient() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getMetaStoreSaslProperties(HiveConf) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Read and return the meta store Sasl configuration.
getMetaStoreSchemaVersion() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getMetaStoreSchemaVersion() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getMetaStoreScriptDir() - Method in class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
Find the directory of metastore scripts
getMetastoreSiteLocation() - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
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
 
getMetrics() - Method in interface org.apache.hive.spark.client.JobHandle
A collection of metrics collected from the Spark jobs triggered by this job.
getMin() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
getMiniDfs(Configuration, int, boolean, String[]) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getMiniDfs(Configuration, int, boolean, String[]) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getMiniDfs(Configuration, int, boolean, String[]) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Returns a shim to wrap MiniDFSCluster.
getMiniMrCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
Returns a shim to wrap MiniMrCluster
getMiniMrCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
Returns a shim to wrap MiniMrCluster
getMiniMrCluster(Configuration, int, String, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Returns a shim to wrap MiniMrCluster
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 class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
optional sint32 minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatisticsOrBuilder
optional sint32 minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 minimum = 1;
getMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
optional sint64 minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatisticsOrBuilder
optional sint64 minimum = 1;
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the minimum string.
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.TimestampColumnStatistics
Get the minimum value for the column.
getMinimumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
getMinimumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string minimum = 1;
getMinimumBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string minimum = 1;
getMinimumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
getMinimumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string minimum = 1;
getMinimumBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string minimum = 1;
getMinimumScale() - Method in enum org.apache.hive.service.cli.Type
Minimum scale supported for this type
getMinimumTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMinimumTransactionId() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getMiniSparkCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getMiniSparkCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
Returns a shim to wrap MiniSparkOnYARNCluster
getMiniSparkCluster(Configuration, int, String, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getMiniTezCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getMiniTezCluster(Configuration, int, String, int) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
Returns a shim to wrap MiniMrTez
getMiniTezCluster(Configuration, int, String, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getMinor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Get the minor version number.
getMinorVersion() - Method in class org.apache.hive.jdbc.HiveDriver
Returns the minor version of this driver.
getMinReducer() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getMinReduceTasks() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
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
 
getMinutes() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
getMjOpSizes() - Method in class org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext
 
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
 
getModifiedRowCount() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
getMonitoredJobs() - Method in interface org.apache.hive.spark.client.JobContext
Return a map from client job Id to corresponding JavaFutureActions.
getMonths() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
getMoreResults() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getMoreResults(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getMoreResults() - Method in class org.apache.hive.jdbc.HiveStatement
 
getMoreResults(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
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(URI) - Method in class org.apache.hadoop.hive.ql.Context
 
getMRTmpPath() - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store map-reduce intermediate data in.
getMS() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Get a cached RawStore.
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
 
getMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getMStringStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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
 
getMy_16bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_32bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_64bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_binary() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_byte() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_double() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
getMy_enum_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_string_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_stringlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_stringlist_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_struct_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_struct_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_structlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enum_structlist_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumlistIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumlistSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumsetIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_enumsetSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
getMy_string_enum_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_string_enum_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_string_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_string_string_mapSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringlistIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringlistSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringsetIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_stringsetSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structlistIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structlistSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structsetIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMy_structsetSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
getMyint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
getMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getMyString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
getMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getMyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
getMyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
getName() - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getName() - Method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MType
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
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.ColumnStatsUpdateTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
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.ExplainSQRewriteTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
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.OrcFileMergeOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
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.spark.SparkTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatistic
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
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 class org.apache.hadoop.hive.ql.io.merge.MergeFileTask
 
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.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
getName() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
optional string name = 1;
getName() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItemOrBuilder
optional string name = 1;
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.lib.TypeRule
 
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 enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.AlterTableTypes
 
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.MergeJoinWork
 
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.SparkWork.Dependency
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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.GenericUDFToUnixTimeStamp
 
getName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUtcTimestamp
 
getName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnixTimeStamp
 
getName() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
getName() - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
getName() - Method in class org.apache.hive.hcatalog.api.HCatDatabase
Gets the database name.
getName() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
Returns name of the field
getName() - Method in class org.apache.hive.service.AbstractService
 
getName() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getName() - Method in enum org.apache.hive.service.cli.Type
 
getName() - Method in class org.apache.hive.service.FilterService
 
getName() - Method in interface org.apache.hive.service.Service
Get the name of this service.
getName() - Method in class org.apache.hive.spark.counter.SparkCounter
 
getName2() - Method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay.DayOfWeek
 
getName3() - Method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay.DayOfWeek
 
getNameBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
optional string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItemOrBuilder
optional string name = 1;
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.metastore.api.RequestPartsSpec
 
getNames() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getNames() - Method in class org.apache.hadoop.hive.ql.io.AvroStorageFormatDescriptor
 
getNames() - Method in class org.apache.hadoop.hive.ql.io.ORCFileStorageFormatDescriptor
 
getNames() - Method in class org.apache.hadoop.hive.ql.io.ParquetFileStorageFormatDescriptor
 
getNames() - Method in class org.apache.hadoop.hive.ql.io.RCFileStorageFormatDescriptor
 
getNames() - Method in class org.apache.hadoop.hive.ql.io.SequenceFileStorageFormatDescriptor
 
getNames() - Method in interface org.apache.hadoop.hive.ql.io.StorageFormatDescriptor
Return the set of names this storage format is known as.
getNames() - Method in class org.apache.hadoop.hive.ql.io.TextFileStorageFormatDescriptor
 
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
 
getNames() - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
getNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getNameToDestPartition() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getNameToDestTable() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
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
 
getNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
getNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
getNameToTypePtrSize() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
getNameToTypePtrSize() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
getNanos() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
getNanos() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getNanos(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getNanoTime(Timestamp, boolean) - Static method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTimeUtils
 
getNCharacterStream(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNCharacterStream(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNCharacterStream(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getNCharacterStream(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getNClob(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNClob(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNClob(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getNClob(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getNDVPartitionColumn(Set<Partition>, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
 
getNeededColIndxsFrmReloptHT() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
getNeededColumnIDs() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getNeededColumnIDs() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getNeededColumns() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getNeededColumns() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getNeedLock() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getNeedsEscape() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getNeedsTagging() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getNegotiatedProperty(String) - Method in class org.apache.hive.service.auth.PlainSaslServer
 
getNetworkTimeout() - Method in class org.apache.hive.jdbc.HiveConnection
 
getNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
getNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
getNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getNew_partsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
getNew_partsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
getNew_partsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getNew_partsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
getNew_partsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
getNew_partsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
getNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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.GenericUDAFDateStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
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(PrimitiveType, int, ConverterParent) - 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.
getNewFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
getNewIndex() - Method in class org.apache.hadoop.hive.metastore.events.AlterIndexEvent
 
getNewIndex() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterIndexEvent
 
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
 
getNewLLBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag.GenericUDAFLagEvaluator
 
getNewLLBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead.GenericUDAFLeadEvaluator
 
getNewLLBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
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
 
getNewPartition() - Method in class org.apache.hadoop.hive.metastore.events.AlterPartitionEvent
 
getNewPartition() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterPartitionEvent
 
getNewPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getNewTable() - Method in class org.apache.hadoop.hive.metastore.events.AlterTableEvent
 
getNewTable() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterTableEvent
 
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
 
getNewValue() - Method in class org.apache.hadoop.hive.metastore.events.ConfigChangeEvent
 
getNext() - Method in interface org.apache.hadoop.hive.ql.io.orc.PositionProvider
 
getNextBlockStart() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getNextCntr(long) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getNextEventId() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationNextId
 
getNextNotification(long, int, IMetaStoreClient.NotificationFilter) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getNextNotification(long, int, IMetaStoreClient.NotificationFilter) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the next set of notifications from the database.
getNextNotification(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getNextNotification(NotificationEventRequest) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Get the next notification event.
getNextNotification(long, int, IMetaStoreClient.NotificationFilter) - Method in class org.apache.hive.hcatalog.api.HCatClient
Get a list of notifications
getNextNotification(long, int, IMetaStoreClient.NotificationFilter) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getNextResult(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
getNextResult(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator
 
getNextResult(GenericUDAFStreamingEvaluator.SumAvgEnhancer<T1, T2>.SumAvgStreamingState) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
getNextResult(GenericUDAFEvaluator.AggregationBuffer) - Method in interface org.apache.hadoop.hive.ql.udf.generic.ISupportStreamingModeForWindowing
 
getNextRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row.
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetCatalogsOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetColumnsOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetFunctionsOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetSchemasOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetTablesOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetTableTypesOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.GetTypeInfoOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.HiveCommandOperation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.Operation
 
getNextRowSet() - Method in class org.apache.hive.service.cli.operation.Operation
 
getNextRowSet(FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.SQLOperation
 
getNextSeqNumber() - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
getNextSize(long) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getNextSpillPartition() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
getNextSplits() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getNextTag() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNextToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Get the next Token.
getNextToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Get the next Token.
getNextValuesTempTableSuffix() - Method in class org.apache.hadoop.hive.ql.session.SessionState
Get the next suffix to use in naming a temporary table created by insert...values
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.
getNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getNonCachedFileSystem(URI, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getNonCachedFileSystem(URI, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getNonCachedFileSystem(URI, Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getNonCachedFileSystem(URI, Configuration) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
getNonCumulativeCost(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
getNonCumulativeCost(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
getNonCumulativeCost(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
getNonCumulativeCost(RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
getNonEquiJoinPredicateElements() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getNonFinalCandidates() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns list of non-final candidate predicate for each map.
getNonPartColInfoMap() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getNonPartColumns() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getNoOfNonVirtualCols() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getNoOperationTime() - Method in interface org.apache.hive.service.cli.session.HiveSession
 
getNoOperationTime() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getNoOpHiveHistoryProxy() - Static method in class org.apache.hadoop.hive.ql.history.HiveHistoryProxyHandler
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getNormalizedFunctionName(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
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
 
getNosuch() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getNosuchIterator() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getNosuchSize() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
getNotDeniedPartns() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getNotifiedTime() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The time when the callback was sent.
getNoUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getNString(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNString(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getNString(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getNString(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
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.
getNullable() - Method in enum org.apache.hive.service.cli.Type
Can you use NULL for this type?
getNullExprProcessor() - 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
 
getNulls() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
getNulls() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
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
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
Returns the NullSequence for this array.
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getNullSequence() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
getNullString() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getNum_txns() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
getNumber() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
getNumber() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
getNumber() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
getNumber() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
getNumberBuckets() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNumberOfPartitions() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 numberOfRows = 6;
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 numberOfRows = 6;
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 numberOfRows = 6;
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 numberOfRows = 5;
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 numberOfRows = 5;
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 numberOfRows = 5;
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the number of rows in the file.
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
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.
getNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
Row count gets updated when flushing the stripes.
getNumberOfValues() - Method in interface org.apache.hadoop.hive.ql.io.orc.ColumnStatistics
Get the number of values in this column.
getNumberOfValues() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional uint64 numberOfValues = 1;
getNumberOfValues() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional uint64 numberOfValues = 1;
getNumberOfValues() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional uint64 numberOfValues = 1;
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.metastore.api.StorageDescriptor
 
getNumBuckets() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
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.CommonMergeJoinDesc
 
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
 
getNumBuckets() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getNumBuckets() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the number of buckets.
getNumBuckets() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the number of buckets.
getNumBucketsExplain() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getNumChild() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getNumChild() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getNumCounter() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
 
getNumDays() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getNumDestinationConsumerTasks(int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
getNumDestinationTaskPhysicalInputs(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
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getNumDVs() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
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
 
getNumericFunctions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getNumExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get NumExprProcessor.
getNumFalses() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
getNumFalses() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getNumFalses() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
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
 
getNumHashFunctions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
optional uint32 numHashFunctions = 1;
getNumHashFunctions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
optional uint32 numHashFunctions = 1;
getNumHashFunctions() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterOrBuilder
optional uint32 numHashFunctions = 1;
getNumHashFunctions() - Method in class org.apache.hive.common.util.BloomFilter
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
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.metastore.api.BinaryColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getNumNulls() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
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
 
getNumParent() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getNumPartitions() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getNumPartitions() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
getNumPartitions() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
getNumPartsCached() - Method in class org.apache.hadoop.hive.metastore.AggregateStatsCache.AggrColStats
 
getNumPaths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the number of Paths in the split.
getNumPrecRadix() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getNumPrecRadix() - Method in enum org.apache.hive.service.cli.Type
Radix for this type (typically either 2 or 10) Null is returned for data types where this is not applicable.
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
getNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
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) - 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
 
getNumSubQueryPredicates() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumTrues() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
getNumTrues() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getNumTrues() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getNumTrues() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getNumValues() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Number of values in the hashmap This is equal to or bigger than number of keys, since some values may share the same key
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
getO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
getO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
getObj() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getObject() - Method in class org.apache.hadoop.hive.hbase.LazyHBaseRow
 
getObject() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getObject() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getObject() - Method in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
Returns the primitive object represented by this LazyObject.
getObject() - Method in interface org.apache.hadoop.hive.serde2.lazy.LazyObjectBase
If the LazyObjectBase is a primitive Object, then deserialize it and return the actual primitive Object.
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
Returns the primitive object represented by this LazyBinaryObject.
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
 
getObject() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
getObject() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObject
Get the Object.
getObject(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getObject(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getObject(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(int, Class<T>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(String, Class<T>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getObject(String, Class<T>) - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getObject(int, Class<T>) - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getObjectDefinition() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectInspector() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
getObjectInspector() - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource
 
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.orc.ReaderImpl
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.AbstractDeserializer
Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.avro.AvroObjectInspectorGenerator
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
getObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.Deserializer
Deprecated.
Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Returns the ObjectInspector for the row.
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Returns the ObjectInspector for the row.
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
getObjectInspector() - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
Return an object inspector that can read through the object that we return from deserialize().
getObjectInspector() - Method in class org.apache.hive.hcatalog.data.JsonSerDe
Returns an object inspector for the specified schema that is capable of reading in the object representation of the JSON string
getObjectInspectorName(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the class names of the ObjectInspector hierarchy.
getObjectInspectorOptions() - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
getObjectInspectorOptions() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
getObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getObjectInspectors() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Returns the array of ObjectInspectors that are for each of the tags.
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.metastore.api.HiveObjectRef
 
getObjectName() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectName() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getObjectType() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectTypePtr() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
getObsolete() - Method in interface org.apache.hadoop.hive.ql.io.AcidUtils.Directory
Get the list of obsolete directories.
getOfClass() - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
getOffset() - Method in class org.apache.hadoop.hive.common.DiskRange
 
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.OrcProto.StripeInformation.Builder
optional uint64 offset = 1;
getOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 offset = 1;
getOffset() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 offset = 1;
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.
getOffset() - Method in class org.apache.hadoop.hive.serde2.avro.AvroSchemaRetriever
Possible offset associated with schema.
getOffset() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
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
 
getOldIndex() - Method in class org.apache.hadoop.hive.metastore.events.AlterIndexEvent
 
getOldIndex() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterIndexEvent
 
getOldName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOldPartition() - Method in class org.apache.hadoop.hive.metastore.events.AlterPartitionEvent
 
getOldPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getOldPartVals() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterPartitionEvent
 
getOldTable() - Method in class org.apache.hadoop.hive.metastore.events.AlterTableEvent
 
getOldTable() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterTableEvent
 
getOldValue() - Method in class org.apache.hadoop.hive.metastore.events.ConfigChangeEvent
 
getOp() - Method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
getOp(BaseWork, Class<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.SparkMapJoinResolver
 
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
 
getOpcode() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
getOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
getOpen_txnsIterator() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
getOpen_txnsIterator() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
getOpen_txnsSize() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
getOpen_txnsSize() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
getOpenSessionCount() - Method in class org.apache.hive.service.cli.session.SessionManager
 
getOpenSessions() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
getOpenTxns() - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
getOpenTxnsInfo() - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
GetOpenTxnsInfoResponse - Class in org.apache.hadoop.hive.metastore.api
 
GetOpenTxnsInfoResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
GetOpenTxnsInfoResponse(long, List<TxnInfo>) - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
GetOpenTxnsInfoResponse(GetOpenTxnsInfoResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
Performs a deep copy on other.
GetOpenTxnsInfoResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetOpenTxnsResponse - Class in org.apache.hadoop.hive.metastore.api
 
GetOpenTxnsResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
GetOpenTxnsResponse(long, Set<Long>) - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
GetOpenTxnsResponse(GetOpenTxnsResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
Performs a deep copy on other.
GetOpenTxnsResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getOperation() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getOperation(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationException() - Method in class org.apache.hive.service.cli.OperationStatus
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
getOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
getOperationId() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getOperationId() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
getOperationLog() - Method in class org.apache.hive.service.cli.operation.Operation
 
getOperationLogByThread() - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationLogRowSet(OperationHandle, FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationLogSessionDir() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Get the session dir, which is the parent dir of operation logs
getOperationLogSessionDir() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getOperationManager() - Method in class org.apache.hive.service.cli.session.SessionManager
 
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
 
getOperationName() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getOperationNextRowSet(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationNextRowSet(OperationHandle, FetchOrientation, long) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationResultSetSchema(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
getOperationState(TOperationState) - Static method in enum org.apache.hive.service.cli.OperationState
 
getOperationState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getOperationStatus(OperationHandle) - Method in class org.apache.hive.service.cli.CLIService
 
getOperationStatus(OperationHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getOperationStatus(OperationHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
getOperationStatus(OperationHandle) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
GetOperationStatus(TGetOperationStatusReq, AsyncMethodCallback<TCLIService.AsyncClient.GetOperationStatus_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetOperationStatus(TGetOperationStatusReq, AsyncMethodCallback<TCLIService.AsyncClient.GetOperationStatus_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetOperationStatus(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetOperationStatus(TGetOperationStatusReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetOperationStatus(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getOperationStatus(OperationHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getOperationTimeout() - Method in class org.apache.hive.service.cli.operation.Operation
 
getOperationType() - Method in class org.apache.hive.service.cli.OperationHandle
 
getOperationType(TOperationType) - Static method in enum org.apache.hive.service.cli.OperationType
 
getOperationType() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
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
 
getOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorId() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
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.OrcFileMergeOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
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.VectorSelectOperator
 
getOperatorToTableAccessMap() - Method in class org.apache.hadoop.hive.ql.parse.TableAccessInfo
 
getOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOpLoggingLevel() - Method in class org.apache.hadoop.hive.ql.session.OperationLog
 
getOpProps() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
getOpProps() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
getOpTaskMap() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getOpToConstantExprs() - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
getOpToDelete() - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
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
 
getOpTreeSkel(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getOpts() - Method in class org.apache.hive.beeline.BeeLine
 
getOrcOptions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater.OrcOptions
 
getOrcProtoUserMetadata() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
getOrder() - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
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
 
getOrderedColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap.Mapping
 
getOrderExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
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.
getOrdinalPos() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getOrdinalPosition() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getOrientation() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
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.
getOriginalLocation(Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getOriginalSubQueryASTForRewrite() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getOrigTable() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getOrReplace() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getOtherTypeFromNullableType(Schema) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
In a nullable type, get the schema for the non-nullable type.
getOuputForRowBytes() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getOuputVectorizationContext() - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorizationContextRegion
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
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
 
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
 
getOuterQueryLimit() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
getOuterQueryPostJoinCond() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewrite
 
getOuterQueryPostJoinCond() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewriteNoop
 
getOutExpr(ExprNodeGenericFuncDesc, Object[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getOutput() - Method in class org.apache.hadoop.hive.common.io.CachingPrintStream
 
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.CastStringToIntervalDayTime
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.gen.CastDateToBooleanViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColDivideDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColModuloDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarAddDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarDivideDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarModuloDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarMultiplyDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalScalarSubtractDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.IfExprStringGroupColumnStringGroupColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
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.StringGroupColConcatStringScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
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.StringScalarConcatStringGroupCol
 
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.VectorElt
 
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.MatchPath.MatchPathResolver
 
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
 
getOutputColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
Get the output committer for this output format.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
 
getOutputDBLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputDir() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
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
 
getOutputDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getOutputFileFormat() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the output file format.
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.metastore.api.StorageDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.AvroStorageFormatDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.ORCFileStorageFormatDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.ParquetFileStorageFormatDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.RCFileStorageFormatDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.SequenceFileStorageFormatDescriptor
 
getOutputFormat() - Method in interface org.apache.hadoop.hive.ql.io.StorageFormatDescriptor
Return the name of the output format as a string
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.io.TextFileStorageFormatDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
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
 
getOutputFormat() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the output format.
getOutputFormat(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
Gets the output format instance.
getOutputFormat() - Method in class org.apache.hive.hcatalog.pig.HCatStorer
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
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
 
getOutputFormatClass() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
getOutputFormatClassName() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
 
getOutputFormatFinalPath(Path, String, JobConf, HiveOutputFormat<?, ?>, boolean, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Deprecated. 
getOutputFormatSubstitute(Class<?>) - 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.gen.VectorUDAFAvgDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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.MuxOperator.Handler
 
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
 
getOutputPath() - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
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.parse.spark.OptimizeSparkProcContext
 
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
 
getOutputSchema() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getOutputShape() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
getOutputShapeExplain() - 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.CastBooleanToCharViaLongToChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
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.CastLongToVarChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
 
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.CastStringToIntervalDayTime
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.gen.CastDateToBooleanViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColEqualDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColGreaterEqualDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColLessEqualDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColNotEqualDecimalScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarGreaterEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarLessEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDecimalScalarNotEqualDecimalColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncNegateDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDecimalToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.IfExprCharScalarStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringGroupColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarCharScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
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.IfExprStringScalarVarCharScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringScalar
 
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.StringGroupColConcatStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
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.StringScalarConcatStringGroupCol
 
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.VectorElt
 
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
 
getOverriddenConfigurations() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getOwner() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getOwner() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getOwner() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
getOwnerPrincipal() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getOwnerType() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getOwnerType() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getP() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getPaddedValue(String, int) - Static method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
getPaddedValue() - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
getPaddedValue() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
getPairCollection(List<ColumnMapping>) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
Create col fam/qual pairs from pipe separated values, usually from config object.
getParameterCompleters() - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
getParameterMetaData() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getParameterMetaData() - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
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.metastore.api.Database
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
getParameters() - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Getter for the Partition parameters.
getParameters() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
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.
getParameters() - Method in class org.apache.hive.hcatalog.api.HCatPartition
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getParameterTypeInfos(Method, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Get the parameter TypeInfo for a method.
getParams() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getParent(Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
Returns the parent operator in the walk path to the current operator.
getParent() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
getParent(Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
Returns the parent operator in the walk path to the current operator.
getParent() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
getParentDataSizes() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getParentDir() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getParentFSPath(Path) - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
getParentKeyCounts() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getParentLogger() - Method in class org.apache.hive.jdbc.HiveDataSource
 
getParentLogger() - Method in class org.apache.hive.jdbc.HiveDriver
 
getParentOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getParents(SparkTran) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
getParents() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getParents(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
getParents returns all the nodes with edges leading into work
getParents(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getParents returns all the nodes with edges leading into work
getParentSession() - Method in class org.apache.hive.service.cli.operation.Operation
 
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
 
getParquerRecordWriterWrapper(ParquetOutputFormat<ParquetHiveRecord>, JobConf, String, Progressable, Properties) - Method in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
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() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext
 
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
 
getParsed() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
 
getParsed() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getParseInfo() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getParser(HiveConf) - Static method in class org.apache.hadoop.hive.common.jsonexplain.JsonParserFactory
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getParserForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
getPart() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcCtx
 
getPart() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpWalkerCtx
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getPartArchiveLevel() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
getPartColIndexForFilter(Table, ExpressionTree.FilterBuilder) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
Get partition column index in the table partition column list that corresponds to the key that is being filtered on by this tree node.
getPartColInfoMap() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
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
 
getPartCols() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the part columns.
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.optimizer.calcite.RelOptHiveTable
 
getPartColumns() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getPartColumns() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the partition columns of the table.
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(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartition(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartition(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartition() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPartition() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getPartition() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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(Table, Map<String, String>, boolean, String, boolean, List<Path>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns partition metadata
getPartition(Table, Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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
 
getPartition(String, String, Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets the partition.
getPartition(String, String, Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getPartitionCols() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getPartitionColumns(TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
getPartitionColumns(Table) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
return the partition columns from a table instance
getPartitionColumns(Configuration) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Return partitioning columns for this input, can only be called after setInput is called.
getPartitionColumns() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get partitions column statistics given dbName, tableName, multiple partitions and colName-s
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get partitions column statistics given dbName, tableName, multiple partitions and colName-s
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Returns the relevant column statistics for given columns in given partitions in a given table in a given database if such statistics exist.
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionColumnStatisticsDesc(MPartitionColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
getPartitionColumnStatisticsInternal(String, String, List<String>, List<String>, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionColumnStatisticsObj(MPartitionColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
getPartitionCount() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPartitionDesc(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPartitionDescFromPath(Map<String, PartitionDesc>, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
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
 
getPartitionExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getPartitionInfo() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
Gets the partition info.
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
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.events.AddPartitionEvent
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.events.DropPartitionEvent
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.events.PreDropPartitionEvent
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Iterator to the (virtual) sequence of Partitions represented by the PartitionSpec.
getPartitionIterator() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
getPartitionIterator() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec
Getter for an Iterator to the first HCatPartition in the HCatPartitionSpec.
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPartitionKeys(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
getPartitionKeysIterator() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeysSize() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeyValMap() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Getter for partition-spec map.
getPartitionKeyValues() - Method in class org.apache.hadoop.hive.metastore.events.InsertEvent
 
getPartitionKeyValues() - Method in class org.apache.hive.hcatalog.messaging.InsertMessage
Get the map of partition keyvalues.
getPartitionKeyValues() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getPartitionList() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getPartitionMetadata(Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getPartitionName() - Method in class org.apache.hadoop.hive.metastore.events.LoadPartitionDoneEvent
 
getPartitionName() - Method in class org.apache.hadoop.hive.metastore.events.PreLoadPartitionDoneEvent
 
getPartitionName() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getPartitionName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getPartitionName() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
getPartitionnames() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
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
 
getPartitionnamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getPartitionnamesSize() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getPartitionPath(Database, String, LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getPartitionPath(Path, LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getPartitionPath() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getPartitionPrivilegeSet(String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionPrivilegeSet(String, String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
getPartitions() - Method in class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
 
getPartitions(String, String, int) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitions(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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(Table, Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getPartitions() - Method in class org.apache.hadoop.hive.ql.parse.EximUtil.ReadMetaData
 
getPartitions() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getPartitions(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets all the partitions.
getPartitions(String, String, Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets all the partitions that match the specified (and possibly partial) partition specification.
getPartitions(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getPartitions(String, String, Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getPartitions() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
 
getPartitions() - Method in class org.apache.hive.hcatalog.messaging.AddPartitionMessage
Getter for list of partitions added.
getPartitions() - Method in class org.apache.hive.hcatalog.messaging.DropPartitionMessage
 
getPartitions() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getPartitions() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getPartitionsByExpr(String, String, byte[], String, short, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByExpr(String, String, byte[], String, short, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionsByExpr(Table, ExprNodeGenericFuncDesc, HiveConf, List<Partition>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get a list of Partitions by expr.
getPartitionsByExprInternal(String, String, byte[], String, short, List<Partition>, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByFilter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionsByFilter(Table, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get a list of Partitions by filter.
getPartitionsByFilterInternal(String, String, String, short, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByNames(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartitionsByNames(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get partitions by a list of partition names.
getPartitionsByNames(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByNames(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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.
getPartitionsByNamesInternal(String, String, List<String>, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionSchema() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the value of partitionSchema.
getPartitionsInternal(String, String, int, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsIterator() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
getPartitionsIterator() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
getPartitionsIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
getPartitionsIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
getPartitionsIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
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
 
getPartitionSpec() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Deprecated.
getPartitionSpecs() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
getPartitionSpecs() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
getPartitionSpecs(String, String, int) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets partitions in terms of generic HCatPartitionSpec instances.
getPartitionSpecs(String, String, Map<String, String>, int) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets partitions in terms of generic HCatPartitionSpec instances.
getPartitionSpecs(String, String, int) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getPartitionSpecs(String, String, Map<String, String>, int) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getPartitionSpecsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
getPartitionsSize() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
getPartitionsSize() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
getPartitionsSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
getPartitionsSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
getPartitionsSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
getPartitionsWithAuth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsWithAuth(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionVals() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getPartitionValsIterator() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getPartitionValsSize() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getPartitionValues() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Gets the value of partitionValues
getPartitionValues() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the partition values.
getPartitionWithAuth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionWithAuth(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionWithAuthInfo(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartitionWithAuthInfo(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartKey() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
getPartKeys() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getPartKeySpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
getPartKeyString() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
getPartKeyValuesForCustomLocation(Map<String, String>, OutputJobInfo, String) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatFileUtil
 
getPartKVPairStringArray(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
getPartList() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getPartName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
getPartname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getPartName() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsUpdateWork
 
getPartNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getPartNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getPartNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getPartParams() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getParts() - Method in class org.apache.hadoop.hive.hbase.HBaseCompositeKey
Return the different parts of the key.
getParts() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
getParts() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
getPartSchemaFromTableSchema(StorageDescriptor, StorageDescriptor, Map<String, String>, String, String, List<FieldSchema>, Properties) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Get partition level schema from table level schema.
getPartsFound() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
getPartsIterator() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
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
 
getPartsSize() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
getPartStats() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
getPartStatsSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
getPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPartValuesFromPartName(String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
getPartValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPartValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPassword(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getPassword(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getPassword(Configuration, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Use password API (if available) to fetch credentials/password
getPassword() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getPassword() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getPassword() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getPasswordMethod - Static variable in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
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
 
getPath(Object, ObjectInspector, PTFPartition.PTFPartitionIterator<Object>, int) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
getPath(TempletonStorage.Type) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
Get the path to storage based on the type.
getPath(TempletonStorage.Type, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
Static method to get the path based on the type.
getPath(TempletonStorage.Type) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Get the path based on the job type.
getPathLists() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getPathOrParentThatExists(FileSystem, Path) - Static method in class org.apache.hadoop.hive.common.FileUtils
Find the parent of path that exists, if path does not exist
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
 
getPaths(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
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
 
getPathWithoutSchemeAndAuthority(Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getPathWithoutSchemeAndAuthority(Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getPathWithoutSchemeAndAuthority(Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
getPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
getPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
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
 
getpCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.PushdownTuple
 
getPctx() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
getPercent() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getPercentComplete() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The percent complete of a job
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
 
getPermFromString(String) - Static method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
Parse ACL permission string, from ZooKeeperMain private method
getPersistenceManager() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
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
 
getPlainProcessorFactory(ThriftCLIService) - Static method in class org.apache.hive.service.auth.PlainSaslHelper
 
getPlainTransport(String, String, TTransport) - Static method in class org.apache.hive.service.auth.PlainSaslHelper
 
getPlainTransportFactory(String) - Static method in class org.apache.hive.service.auth.PlainSaslHelper
 
getPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getPlanPath(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPort() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getPort() - Method in class org.apache.hive.spark.client.rpc.RpcServer
 
getPortNumber() - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getPos() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
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
Deprecated.
 
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.OrcFileStripeMergeRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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
 
getPos() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
Return the amount of data processed.
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.common.io.NonSyncByteArrayInputStream
 
getPosition(String) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getPosition() - Method in class org.apache.hadoop.hive.ql.exec.tez.DataInputByteBuffer
 
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
 
getPosition(String) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
Note : The position will be re-numbered when one of the preceding columns are removed.
getPosition() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
getPositionFromHiveInternalColumnName(String) - Method in class org.apache.hive.hcatalog.data.JsonSerDe
 
getPositionFromInternalName(String) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
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
 
getPositions(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
getPositions(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
repeated uint64 positions = 1 [packed = true];
getPositions(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
repeated uint64 positions = 1 [packed = true];
getPositionsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
getPositionsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
repeated uint64 positions = 1 [packed = true];
getPositionsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
repeated uint64 positions = 1 [packed = true];
getPositionsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
getPositionsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
repeated uint64 positions = 1 [packed = true];
getPositionsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
repeated uint64 positions = 1 [packed = true];
getPosOfDynPartCols() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getPosOfPartCols() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getPostJoinFilters() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getPosToAliasMap() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getPosToAliasMap() - Method in class org.apache.hadoop.hive.ql.plan.SparkBucketMapJoinContext
 
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
 
getPrecision() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 precision = 5;
getPrecision() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 precision = 5;
getPrecision() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 precision = 5;
getPrecision() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
getPrecision(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getPrecision() - Method in class org.apache.hive.service.cli.TypeDescriptor
Maximum precision for numeric types.
getPrecision() - Method in class org.apache.hive.service.cli.TypeQualifiers
 
getPrecisionForType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
Need to keep consistent with JdbcColumn.columnPrecision
getPredicate() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
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
 
getPreUpgradeScriptName(int, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
 
getPrimaryKeys(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getPrimarySeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Inspect the separators this instance is configured with.
getPrimitiveCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the associated primitive category for this primitive ObjectInspector.
getPrimitiveCategory() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Get the primitive category of the PrimitiveObjectInspector.
getPrimitiveCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
getPrimitiveCategory() - Method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
May return null
getPrimitiveCompare() - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.CompareOp
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Equal
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThan
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThanOrEqual
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThan
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThanOrEqual
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Like
 
getPrimitiveCompare() - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.NotEqual
 
getPrimitiveComparison(String, IndexSearchCondition) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
getPrimitiveComparisonClass(String) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
getPrimitiveEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getPrimitiveGrouping(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Based on the PrimitiveCategory of a type, return the PrimitiveGrouping that the PrimitiveCategory belongs to (numeric, string, date, etc).
getPrimitiveHType(PrimitiveTypeInfo) - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
 
getPrimitiveJavaClass() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
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
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBinaryObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBooleanObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyByteObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDateObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDoubleObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyFloatObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveDecimalObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveIntervalDayTimeObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveIntervalYearMonthObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyIntObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyLongObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyShortObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyVoidObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.BinaryObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.DateObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveCharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveDecimalObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveIntervalDayTimeObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveIntervalYearMonthObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveVarcharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.StringObjectInspector
Get the String representation of the data.
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.TimestampObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBooleanObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDoubleObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableFloatObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableIntObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableLongObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableShortObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableVoidObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Get the Java Primitive object.
getPrimitiveJavaObjectInspector(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns the PrimitiveJavaObjectInspector for the PrimitiveCategory.
getPrimitiveJavaObjectInspector(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns the PrimitiveJavaObjectInspector for the given PrimitiveTypeInfo instance,
getPrimitiveObjectInspectorFromClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns an ObjectInspector for a primitive Class.
getPrimitiveTypeEntry() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
getPrimitiveTypeInfo(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
Get PrimitiveTypeInfo instance for the given type name of a type including types with parameters, such as varchar(20).
getPrimitiveTypeInfoFromJavaPrimitive(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getPrimitiveTypeInfoFromPrimitiveWritable(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getPrimitiveWritableClass() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the associated primitive Writable class for this primitive ObjectInspector.
getPrimitiveWritableClass() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Get the Primitive Writable class which is the return type of getPrimitiveWritableObject() and copyToPrimitiveWritableObject().
getPrimitiveWritableClass() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
getPrimitiveWritableConstantObjectInspector(PrimitiveTypeInfo, Object) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns a PrimitiveWritableObjectInspector which implements ConstantObjectInspector for the PrimitiveCategory.
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
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.AbstractPrimitiveLazyObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBinaryObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.BinaryObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.DateObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveCharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveDecimalObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveIntervalDayTimeObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveIntervalYearMonthObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.HiveVarcharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaVoidObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.StringObjectInspector
Get the Text representation of the data.
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.TimestampObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
getPrimitiveWritableObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Return the data in an instance of primitive writable Object.
getPrimitiveWritableObjectInspector(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns the PrimitiveWritableObjectInspector for the PrimitiveCategory.
getPrimitiveWritableObjectInspector(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns the PrimitiveWritableObjectInspector for the given type info
getPrincipal() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
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.HiveV1Authorizer
 
getPrincipalGrantInfoForRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getPrincipalGrantInfoForRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
getPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
getPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
getPrincipalGrantsIterator() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
getPrincipalGrantsIterator() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
getPrincipalGrantsSize() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
getPrincipalGrantsSize() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
GetPrincipalsInRoleRequest - Class in org.apache.hadoop.hive.metastore.api
 
GetPrincipalsInRoleRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
GetPrincipalsInRoleRequest(String) - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
GetPrincipalsInRoleRequest(GetPrincipalsInRoleRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
Performs a deep copy on other.
GetPrincipalsInRoleRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetPrincipalsInRoleResponse - Class in org.apache.hadoop.hive.metastore.api
 
GetPrincipalsInRoleResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
GetPrincipalsInRoleResponse(List<RolePrincipalGrant>) - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
GetPrincipalsInRoleResponse(GetPrincipalsInRoleResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
Performs a deep copy on other.
GetPrincipalsInRoleResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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.metastore.api.PrivilegeGrantInfo
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
getPrivilegeInfos(List<HiveObjectPrivilege>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
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
getPrivilegesIterator() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrivObjectType(PrivilegeObjectDesc) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
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
getProcedureColumns(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getProcedures(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getProcedureTerm() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getProcessedLocation(Path) - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
getProgress() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
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
Deprecated.
 
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.OrcFileStripeMergeRecordReader
Default progress will be based on number of files processed.
getProgress() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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.
getProgress() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
Return progress based on the amount of data processed so far.
getProgress() - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
getProgress() - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
getProjectedColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getProjectedColumnsUncompressedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
getProjectionColumnMap() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getProjectionColumnNames() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getProjsFromBelowAsInputRef(RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getProjsFromLeftPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsFromLeftPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getProjsFromLeftPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsFromLeftPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
NOTE: Join Schema = left Schema + (right Schema offset by left.fieldcount).
getProjsFromRightPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsFromRightPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getProjsFromRightPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsFromRightPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getProjsJoinKeysInChildSchema(int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsJoinKeysInChildSchema(int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getProjsJoinKeysInJoinSchema(int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
getProjsJoinKeysInJoinSchema(int) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
getPropagatedConstants(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
Get propagated constant map from parents.
getProperties() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
getProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getProperties() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getProperties() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getProperties() - Method in class org.apache.hive.hcatalog.api.HCatDatabase
Gets the dB properties.
getProperties() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Set/Get Property information to be passed down to *StorageHandler implementation put implementation specific storage handler configurations here
getProperties() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Set/Get Property information to be passed down to *StorageHandler implementation put implementation specific storage handler configurations here
getProperties() - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
getPropertiesExplain() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getPropertiesExplain() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getPropertiesExplain(Properties) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
getPropertiesSize() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
getPropertiesSize() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getProperty() - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
getProperty(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPropertyInfo(String, Properties) - Method in class org.apache.hive.jdbc.HiveDriver
 
getPropertyName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getPropertyName(HadoopShims.HCatHadoopShims.PropertyName) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
getPropName() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.OrcTableProperties
 
getPropName() - Method in enum org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils.AvroTableProperties
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getProtectMode(Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getProtectMode(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getProtectModeFromString(String) - Static method in class org.apache.hadoop.hive.metastore.ProtectMode
 
getProtectModeType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getProtocol(TTransport) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol.Factory
 
getProtocol(TTransport) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol.Factory
 
getProtocol() - Method in class org.apache.hive.jdbc.HiveConnection
 
getProtocolFactoryByName(String) - Static method in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
getProtocolVersion() - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
getProtocolVersion() - Method in class org.apache.hive.service.cli.operation.Operation
 
getProtocolVersion() - Method in class org.apache.hive.service.cli.OperationHandle
 
getProtocolVersion() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getProtocolVersion() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getProtocolVersion() - Method in class org.apache.hive.service.cli.SessionHandle
 
getProxy(HiveConf, Configuration, String, int) - Static method in class org.apache.hadoop.hive.metastore.RawStoreProxy
 
getProxy(HiveConf, IHMSHandler, boolean) - Static method in class org.apache.hadoop.hive.metastore.RetryingHMSHandler
 
getProxy(HiveConf) - Static method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
getProxy(HiveConf, HiveMetaHookLoader, String) - Static method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
getProxy(HiveConf, HiveMetaHookLoader, Map<String, Long>, String) - Static method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
getProxy(HiveConf, Class<?>[], Object[], String) - Static method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
This constructor is meant for Hive internal use only.
getProxy(HiveConf, Class<?>[], Object[], Map<String, Long>, String) - Static method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
This constructor is meant for Hive internal use only.
getProxy(HiveSession, UserGroupInformation) - Static method in class org.apache.hive.service.cli.session.HiveSessionProxy
 
getProxyUserName() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
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
 
getPrunedPartitionList() - Method in class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
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
 
getPrunedRowType() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
getPseudoColumns(String, String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
getPublicId() - Method in class org.apache.hive.service.cli.HandleIdentifier
 
getPublisher(Configuration) - Method in enum org.apache.hadoop.hive.common.StatsSetupConst.StatDB
 
getPut() - Method in class org.apache.hadoop.hive.hbase.PutWritable
 
getPutTimestamp() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getPvals(List<FieldSchema>, Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Given a list of partition columns and a partial mapping from some partition columns to values the function returns the values for the column.
getQB() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getQb() - Method in class org.apache.hadoop.hive.ql.plan.ExplainSQRewriteWork
 
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
 
getQualifedReducerKeyNames(List<String>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get qualified column name from output key column names
getQualifiedFunctionNameParts(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
getQualifiedName(String, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getQualifiedName(Table) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
getQualifiedName(Partition) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
getQualifiedName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
getQualifiedName(String, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
getQualifiedName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
getQualifiedName(int, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
getQualifiedName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
String representing the qualified type name.
getQualifiedPath(HiveConf, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Convert path to qualified path.
getQualifiedTableName(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getQualifierName() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getQualifierNameBytes() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getQualifierPrefix() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getQualifierPrefixBytes() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
getQualifiers() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
getQualifiersSize() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
getQuantileArray(ConstantObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
getQueries() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Returns an unmodifiable list of queries.
getQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQueriesIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQueriesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQuery() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryCurrentTimestamp() - Method in class org.apache.hadoop.hive.ql.session.SessionState
Get query current timestamp
getQueryDef() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
getQueryDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryFileRegex() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
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
 
getQueryLog() - Method in class org.apache.hive.jdbc.HiveStatement
Get the execution logs of the given SQL statement.
getQueryLog(boolean, int) - Method in class org.apache.hive.jdbc.HiveStatement
Get the execution logs of the given SQL statement.
getQueryMatches() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
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
 
getQueryPlan(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getQueryPlan(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getQueryPlan() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getQueryPlan() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
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
 
getQueryRegex() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getQueryRet() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
The HWISessionItem stores the result of each query in an array.
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
 
getQueryTimeout() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getQueryTimeout() - Method in class org.apache.hive.jdbc.HiveStatement
 
getQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueue() - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
getQueued() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getQueueName() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getQuorumServers(HiveConf) - Static method in class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper
Get the ensemble server addresses from the configuration.
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(long, int, Random) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Introducing a random factor to the wait time before another retry.
getRange() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getRanges(Configuration, ColumnMapper) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
Loop through search conditions and build ranges for predicates involving rowID column, if any.
getRankLimit() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
getRankLimitFunction() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
getRawDataSerializedSize() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
 
getRawDataSerializedSize() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getRawDataSerializedSize() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
 
getRawDataSerializedSize() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
 
getRawDataSerializedSize() - Method in interface org.apache.hadoop.hive.serde2.SerDeStatsStruct
Rerurns the serialized size of the object.
getRawDataSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the deserialized data size of the file
getRawDataSize() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getRawDataSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Return the deserialized data size.
getRawDataSize() - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
Raw data size will be compute when writing the file footer.
getRawDataSize(Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get raw data size of a give table
getRawDataSize() - Method in class org.apache.hadoop.hive.serde2.SerDeStats
Return the raw data size
getRawDataSizeOfColumns(List<String>) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the deserialized data size of the specified columns
getRawDataSizeOfColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getRawDescription() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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
 
getRawInputShapeExplain() - 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
 
getRawStore() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getReadBlockRow(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getReadColumnIDs(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Returns an array of column ids(start from zero) which is set in the given parameter conf.
getReadColumnNames(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
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
 
getReadPoint() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getReadPoint(WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getReadPos() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
Return the thread-safe read position.
getReadPosition() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getReadReqPriv() - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider.DropPrivilegeExtractor
 
getRealClass() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
Deprecated.
Produces the specific class to deserialize.
getRealClass() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Deprecated.
 
getRealm() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
getRealm() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
getRealm() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.KerberosNameShim
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
getRealType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
getRealTypeInstance() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
getRealTypeInstance() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
getRealTypeInstance() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
getRecord() - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
getRecordIdColumn() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getRecordIdentifier() - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat.AcidRecordReader
 
getRecordIdentifier() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getRecordIdentifier() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
getRecordLength() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
Setup accumulo input format from conf properties.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableSnapshotInputFormat
 
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
Deprecated.
 
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.merge.MergeFileInputFormat
 
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.OrcFileStripeMergeInputFormat
 
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.parquet.VectorizedParquetInputFormat
 
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
 
getRecordReader(JobConf, CombineFileSplit, Reporter, Class<RecordReader<K, V>>) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getRecordReader(JobConf, CombineFileSplit, Reporter, Class<RecordReader<K, V>>) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
getRecordReaderID() - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
getRecordSources() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
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.accumulo.mr.HiveAccumuloTableOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
 
getRecordWriter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
getRecordWriter(JobConf, OutputFormat<?, ?>, 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(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileOutputFormat
 
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.RCFileOutputFormat
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
Get the record writer for the job.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceOutputFormat
 
getReduceKeyTableDesc(List<FieldSchema>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for reduce key.
getReducer(MapWork) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
getReducer(MapWork) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkTask
 
getReducer(MapWork) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getReducer(MapWork) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
getReducer() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getReducerTimeStatsPerJobList() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getReducerToReduceWork() - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolver.SparkSkewJoinProcCtx
 
getReducerTraits() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getReduceSinkDesc(ArrayList<ExprNodeDesc>, ArrayList<ExprNodeDesc>, List<String>, boolean, int, ArrayList<ExprNodeDesc>, String, int, AcidUtils.Operation) - 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, AcidUtils.Operation) - 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, AcidUtils.Operation) - 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, AcidUtils.Operation) - 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.ConstantPropagateProcFactory
 
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
 
getReduceSinkRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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
 
getRef(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getRef(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getRef(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getRef(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getReferenceableColumnAliases(TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor
 
getReferenceableColumnAliases(String, int) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Get a list of aliases for non-hidden columns
getReferenceableColumnAliases(TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getReferencedColumns() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getReferencedColumns() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getReferencedColumns() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getReferencedColumns() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
 
getReferencedColumns() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
Provide referenced columns names to be used in partition function
getReferredPartCols() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getRefKey(byte) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getReflectionObjectInspector(Type, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getReflector() - Method in class org.apache.hive.beeline.BeeLine
 
getRegexToLogLines() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getRegistry(Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getRegistry() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getRegistryForWrite() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getRejectedHostZnodePaths() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getRejectedJoinOps() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getRelativePath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getReloadFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getRemoteAddress() - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getRemoteJobState() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getRemoteUser() - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getRemoteUser() - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getRenamePartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRenewer() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
getRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
getReplace() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getReplaceMode() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getReplaceMode() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getReplicationSpec() - Method in class org.apache.hadoop.hive.ql.parse.EximUtil.ReadMetaData
 
getReplicationSpec() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getReplicationState() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
getReplicationTasks(long, int, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Get an iterator that iterates over a list of replication tasks needed to replicate all the events that have taken place for a given db/table.
getReplicationTasks(long, int, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
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
 
getReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
getReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
getReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
getRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
getRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
getRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getRequiredCounterPrefix() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
getRequiredFiles() - Method in class org.apache.hadoop.hive.ql.exec.UDF
This can be overridden to include files required by this 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
This can be overridden to include JARs required by this UDF.
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
 
getRequiredness() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
Get the requiredness attribute of this field.
getRequiredPrivilegeSet() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
getRequiredPrivs(HiveOperationType, HivePrivilegeObject, Operation2Privilege.IOType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.Operation2Privilege
Get the privileges required for this operation (hiveOpType) on hive object (hObj) when its IOType is ioType.
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.ExplainSQRewriteWork
 
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.ShowConfDesc
 
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
 
getResourceManagerAddress(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
 
getResources() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
getResources() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getResourceType() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
getResourceType() - Method in class org.apache.hadoop.hive.metastore.model.MResourceUri
 
getResourceType() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo.FunctionResource
 
getResourceURI() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo.FunctionResource
 
getResourceUris() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getResourceUris() - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
getResourceUrisIterator() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getResourceUrisSize() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
getResponse() - Method in exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
getResponseCode() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getResult() - Method in class org.apache.hadoop.hive.hbase.ResultWritable
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.abort_txn_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_req_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_function_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partitions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.check_lock_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.commit_txn_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.compact_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_function_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_function_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partitions_req_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.exchange_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.fire_listener_event_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_function_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_functions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_next_notification_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_info_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_principals_in_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.getMetaConf_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.lock_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.open_txns_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.rename_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_ugi_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.setMetaConf_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_compact_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_locks_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.unlock_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call
 
getResult(I, ThriftHiveMetastore.abort_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.abort_txn
 
getResult(I, ThriftHiveMetastore.add_dynamic_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_dynamic_partitions
 
getResult(I, ThriftHiveMetastore.add_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_index
 
getResult(I, ThriftHiveMetastore.add_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition
 
getResult(I, ThriftHiveMetastore.add_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition_with_environment_context
 
getResult(I, ThriftHiveMetastore.add_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions
 
getResult(I, ThriftHiveMetastore.add_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_pspec
 
getResult(I, ThriftHiveMetastore.add_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_req
 
getResult(I, ThriftHiveMetastore.alter_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_database
 
getResult(I, ThriftHiveMetastore.alter_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_function
 
getResult(I, ThriftHiveMetastore.alter_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_index
 
getResult(I, ThriftHiveMetastore.alter_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition
 
getResult(I, ThriftHiveMetastore.alter_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition_with_environment_context
 
getResult(I, ThriftHiveMetastore.alter_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partitions
 
getResult(I, ThriftHiveMetastore.alter_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table
 
getResult(I, ThriftHiveMetastore.alter_table_with_cascade_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_cascade
 
getResult(I, ThriftHiveMetastore.alter_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_environment_context
 
getResult(I, ThriftHiveMetastore.append_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition
 
getResult(I, ThriftHiveMetastore.append_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name
 
getResult(I, ThriftHiveMetastore.append_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context
 
getResult(I, ThriftHiveMetastore.append_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_with_environment_context
 
getResult(I, ThriftHiveMetastore.cancel_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.cancel_delegation_token
 
getResult(I, ThriftHiveMetastore.check_lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.check_lock
 
getResult(I, ThriftHiveMetastore.commit_txn_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.commit_txn
 
getResult(I, ThriftHiveMetastore.compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.compact
 
getResult(I, ThriftHiveMetastore.create_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_database
 
getResult(I, ThriftHiveMetastore.create_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_function
 
getResult(I, ThriftHiveMetastore.create_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_role
 
getResult(I, ThriftHiveMetastore.create_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table
 
getResult(I, ThriftHiveMetastore.create_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table_with_environment_context
 
getResult(I, ThriftHiveMetastore.create_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_type
 
getResult(I, ThriftHiveMetastore.delete_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_partition_column_statistics
 
getResult(I, ThriftHiveMetastore.delete_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_table_column_statistics
 
getResult(I, ThriftHiveMetastore.drop_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_database
 
getResult(I, ThriftHiveMetastore.drop_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_function
 
getResult(I, ThriftHiveMetastore.drop_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_index_by_name
 
getResult(I, ThriftHiveMetastore.drop_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition
 
getResult(I, ThriftHiveMetastore.drop_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name
 
getResult(I, ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context
 
getResult(I, ThriftHiveMetastore.drop_partition_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_with_environment_context
 
getResult(I, ThriftHiveMetastore.drop_partitions_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partitions_req
 
getResult(I, ThriftHiveMetastore.drop_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_role
 
getResult(I, ThriftHiveMetastore.drop_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table
 
getResult(I, ThriftHiveMetastore.drop_table_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table_with_environment_context
 
getResult(I, ThriftHiveMetastore.drop_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_type
 
getResult(I, ThriftHiveMetastore.exchange_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.exchange_partition
 
getResult(I, ThriftHiveMetastore.fire_listener_event_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.fire_listener_event
 
getResult(I, ThriftHiveMetastore.get_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_aggr_stats_for
 
getResult(I, ThriftHiveMetastore.get_all_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_databases
 
getResult(I, ThriftHiveMetastore.get_all_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_tables
 
getResult(I, ThriftHiveMetastore.get_config_value_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_config_value
 
getResult(I, ThriftHiveMetastore.get_current_notificationEventId_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_current_notificationEventId
 
getResult(I, ThriftHiveMetastore.get_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_database
 
getResult(I, ThriftHiveMetastore.get_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_databases
 
getResult(I, ThriftHiveMetastore.get_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_delegation_token
 
getResult(I, ThriftHiveMetastore.get_fields_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields
 
getResult(I, ThriftHiveMetastore.get_fields_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields_with_environment_context
 
getResult(I, ThriftHiveMetastore.get_function_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_function
 
getResult(I, ThriftHiveMetastore.get_functions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_functions
 
getResult(I, ThriftHiveMetastore.get_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_by_name
 
getResult(I, ThriftHiveMetastore.get_index_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_names
 
getResult(I, ThriftHiveMetastore.get_indexes_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_indexes
 
getResult(I, ThriftHiveMetastore.get_next_notification_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_next_notification
 
getResult(I, ThriftHiveMetastore.get_open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns
 
getResult(I, ThriftHiveMetastore.get_open_txns_info_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns_info
 
getResult(I, ThriftHiveMetastore.get_part_specs_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_part_specs_by_filter
 
getResult(I, ThriftHiveMetastore.get_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition
 
getResult(I, ThriftHiveMetastore.get_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_by_name
 
getResult(I, ThriftHiveMetastore.get_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_column_statistics
 
getResult(I, ThriftHiveMetastore.get_partition_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names
 
getResult(I, ThriftHiveMetastore.get_partition_names_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names_ps
 
getResult(I, ThriftHiveMetastore.get_partition_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_with_auth
 
getResult(I, ThriftHiveMetastore.get_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions
 
getResult(I, ThriftHiveMetastore.get_partitions_by_expr_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_expr
 
getResult(I, ThriftHiveMetastore.get_partitions_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_filter
 
getResult(I, ThriftHiveMetastore.get_partitions_by_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_names
 
getResult(I, ThriftHiveMetastore.get_partitions_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps
 
getResult(I, ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps_with_auth
 
getResult(I, ThriftHiveMetastore.get_partitions_pspec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_pspec
 
getResult(I, ThriftHiveMetastore.get_partitions_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_statistics_req
 
getResult(I, ThriftHiveMetastore.get_partitions_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_with_auth
 
getResult(I, ThriftHiveMetastore.get_principals_in_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_principals_in_role
 
getResult(I, ThriftHiveMetastore.get_privilege_set_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_privilege_set
 
getResult(I, ThriftHiveMetastore.get_role_grants_for_principal_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_grants_for_principal
 
getResult(I, ThriftHiveMetastore.get_role_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_names
 
getResult(I, ThriftHiveMetastore.get_schema_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema
 
getResult(I, ThriftHiveMetastore.get_schema_with_environment_context_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema_with_environment_context
 
getResult(I, ThriftHiveMetastore.get_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table
 
getResult(I, ThriftHiveMetastore.get_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_column_statistics
 
getResult(I, ThriftHiveMetastore.get_table_names_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_names_by_filter
 
getResult(I, ThriftHiveMetastore.get_table_objects_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_objects_by_name
 
getResult(I, ThriftHiveMetastore.get_table_statistics_req_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_statistics_req
 
getResult(I, ThriftHiveMetastore.get_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_tables
 
getResult(I, ThriftHiveMetastore.get_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type
 
getResult(I, ThriftHiveMetastore.get_type_all_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type_all
 
getResult(I, ThriftHiveMetastore.getMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.getMetaConf
 
getResult(I, ThriftHiveMetastore.grant_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_privileges
 
getResult(I, ThriftHiveMetastore.grant_revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_privileges
 
getResult(I, ThriftHiveMetastore.grant_revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_role
 
getResult(I, ThriftHiveMetastore.grant_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_role
 
getResult(I, ThriftHiveMetastore.heartbeat_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat
 
getResult(I, ThriftHiveMetastore.heartbeat_txn_range_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat_txn_range
 
getResult(I, ThriftHiveMetastore.isPartitionMarkedForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.isPartitionMarkedForEvent
 
getResult(I, ThriftHiveMetastore.list_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_privileges
 
getResult(I, ThriftHiveMetastore.list_roles_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_roles
 
getResult(I, ThriftHiveMetastore.lock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.lock
 
getResult(I, ThriftHiveMetastore.markPartitionForEvent_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.markPartitionForEvent
 
getResult(I, ThriftHiveMetastore.open_txns_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.open_txns
 
getResult(I, ThriftHiveMetastore.partition_name_has_valid_characters_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_has_valid_characters
 
getResult(I, ThriftHiveMetastore.partition_name_to_spec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_spec
 
getResult(I, ThriftHiveMetastore.partition_name_to_vals_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_vals
 
getResult(I, ThriftHiveMetastore.rename_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.rename_partition
 
getResult(I, ThriftHiveMetastore.renew_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.renew_delegation_token
 
getResult(I, ThriftHiveMetastore.revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_privileges
 
getResult(I, ThriftHiveMetastore.revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_role
 
getResult(I, ThriftHiveMetastore.set_aggr_stats_for_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_aggr_stats_for
 
getResult(I, ThriftHiveMetastore.set_ugi_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_ugi
 
getResult(I, ThriftHiveMetastore.setMetaConf_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.setMetaConf
 
getResult(I, ThriftHiveMetastore.show_compact_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_compact
 
getResult(I, ThriftHiveMetastore.show_locks_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_locks
 
getResult(I, ThriftHiveMetastore.unlock_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.unlock
 
getResult(I, ThriftHiveMetastore.update_partition_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_partition_column_statistics
 
getResult(I, ThriftHiveMetastore.update_table_column_statistics_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_table_column_statistics
 
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
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.clean_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
getResult(I, ThriftHive.clean_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.clean
 
getResult(I, ThriftHive.execute_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.execute
 
getResult(I, ThriftHive.fetchAll_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchAll
 
getResult(I, ThriftHive.fetchN_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchN
 
getResult(I, ThriftHive.fetchOne_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchOne
 
getResult(I, ThriftHive.getClusterStatus_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getClusterStatus
 
getResult(I, ThriftHive.getQueryPlan_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getQueryPlan
 
getResult(I, ThriftHive.getSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getSchema
 
getResult(I, ThriftHive.getThriftSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getThriftSchema
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelDelegationToken_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelOperation_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseOperation_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseSession_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.ExecuteStatement_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.FetchResults_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetCatalogs_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetColumns_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetDelegationToken_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetFunctions_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetInfo_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetOperationStatus_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetResultSetMetadata_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetSchemas_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTables_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTableTypes_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTypeInfo_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.OpenSession_call
 
getResult() - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.RenewDelegationToken_call
 
getResult(I, TCLIService.CancelDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelDelegationToken
 
getResult(I, TCLIService.CancelOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelOperation
 
getResult(I, TCLIService.CloseOperation_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseOperation
 
getResult(I, TCLIService.CloseSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseSession
 
getResult(I, TCLIService.ExecuteStatement_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.ExecuteStatement
 
getResult(I, TCLIService.FetchResults_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.FetchResults
 
getResult(I, TCLIService.GetCatalogs_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetCatalogs
 
getResult(I, TCLIService.GetColumns_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetColumns
 
getResult(I, TCLIService.GetDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetDelegationToken
 
getResult(I, TCLIService.GetFunctions_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetFunctions
 
getResult(I, TCLIService.GetInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetInfo
 
getResult(I, TCLIService.GetOperationStatus_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetOperationStatus
 
getResult(I, TCLIService.GetResultSetMetadata_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetResultSetMetadata
 
getResult(I, TCLIService.GetSchemas_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetSchemas
 
getResult(I, TCLIService.GetTables_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTables
 
getResult(I, TCLIService.GetTableTypes_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTableTypes
 
getResult(I, TCLIService.GetTypeInfo_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTypeInfo
 
getResult(I, TCLIService.OpenSession_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.OpenSession
 
getResult(I, TCLIService.RenewDelegationToken_args) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.RenewDelegationToken
 
getResultBucket() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
gets the value for resultBucket.
getResultBucketMaxSize() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
returns the value for resultBucketMaxSize.
getResultExprInfo() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
getResultExprInfo() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExpressionParser
 
getResultExprNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExprInfo
 
getResultExprNodes() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExprInfo
 
getResultFile() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getResults(List) - Method in class org.apache.hadoop.hive.ql.Driver
 
getResults() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.exec.ExplainSQRewriteTask
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
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.ExplainSQRewriteSemanticAnalyzer
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getResultsDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getResultSet() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getResultSet() - Method in class org.apache.hive.jdbc.HiveStatement
 
getResultSetConcurrency() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getResultSetConcurrency() - Method in class org.apache.hive.jdbc.HiveStatement
 
getResultSetHoldability() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getResultSetHoldability() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getResultSetHoldability() - Method in class org.apache.hive.jdbc.HiveStatement
 
getResultSetMetadata(OperationHandle) - Method in class org.apache.hive.service.cli.CLIService
 
getResultSetMetadata(OperationHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getResultSetMetadata(OperationHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
getResultSetMetadata(OperationHandle) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
getResultSetMetadata(OperationHandle) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetResultSetMetadata(TGetResultSetMetadataReq, AsyncMethodCallback<TCLIService.AsyncClient.GetResultSetMetadata_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetResultSetMetadata(TGetResultSetMetadataReq, AsyncMethodCallback<TCLIService.AsyncClient.GetResultSetMetadata_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetResultSetMetadata(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetResultSetMetadata(TGetResultSetMetadataReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetResultSetMetadata(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getResultSetMetadata(OperationHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetCatalogsOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetColumnsOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetFunctionsOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetSchemasOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetTablesOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetTableTypesOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.GetTypeInfoOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.HiveCommandOperation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.Operation
 
getResultSetSchema() - Method in class org.apache.hive.service.cli.operation.SQLOperation
 
getResultSetType() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getResultSetType() - Method in class org.apache.hive.jdbc.HiveStatement
 
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.metastore.api.Table
 
getRetention() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getRetention() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getReturnType(TypeInfo) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getRevision() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the subversion revision number for the root directory
getRevokeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRewrittenQuery() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewrite
 
getRewrittenQuery() - Method in class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.QBSubQueryRewriteNoop
 
getRhs() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
getRHSSemijoinColumns(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
getRight() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
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
 
getRightAliases() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getRightValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
getRightValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
getRightValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
getRightValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
getRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
getRole() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getRole(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getRole(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
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.HiveV1Authorizer
 
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
getRoleGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
GetRoleGrantsForPrincipalRequest - Class in org.apache.hadoop.hive.metastore.api
 
GetRoleGrantsForPrincipalRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
GetRoleGrantsForPrincipalRequest(String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
GetRoleGrantsForPrincipalRequest(GetRoleGrantsForPrincipalRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
Performs a deep copy on other.
GetRoleGrantsForPrincipalRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetRoleGrantsForPrincipalResponse - Class in org.apache.hadoop.hive.metastore.api
 
GetRoleGrantsForPrincipalResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
GetRoleGrantsForPrincipalResponse(List<RolePrincipalGrant>) - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
GetRoleGrantsForPrincipalResponse(GetRoleGrantsForPrincipalResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
Performs a deep copy on other.
GetRoleGrantsForPrincipalResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
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
 
getRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getRolePrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getRoles() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getRoleShowGrantSchema() - Static method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getRoot() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
 
getRootConverter() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter
 
getRootOperators() - Method in class org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext
 
getRootPath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getRootPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getRoots() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
getRoots returns all nodes that do not have a parent.
getRoots() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getRoots returns all nodes that do not have a parent.
getRootsIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getRootsSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
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
 
getRow(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLag
 
getRow(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLead
 
getRow(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getRow() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getRowColNameIndxMap(List<RelDataTypeField>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
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.calcite.RelOptHiveTable
 
getRowCount(Join) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
getRowCount(SemiJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
getRowCount() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getRowCount() - Method in class org.apache.hadoop.hive.serde2.SerDeStats
Return the row count
getRowId() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
getRowId() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
What was the original row id for the last row?
getRowId(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getRowId(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getRowId(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getRowId(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getRowIdColumnMapping() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getRowIdFactory() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getRowIdHiveColumnName() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getRowIdLifetime() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getRowIdMapping() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
getRowIdOffset() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
getRowIdOffset() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
getRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint32 rowIndexStride = 8;
getRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint32 rowIndexStride = 8;
getRowIndexStride() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint32 rowIndexStride = 8;
getRowIndexStride() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the number of rows per a entry in the row index.
getRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
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.
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
getRows() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getRowSchema() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRowsComputedUsingStats() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getRowSeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getRowsIterator() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getRowSkewedIndex() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getRowsRemainingAfterTerminate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
getRowsRemainingAfterTerminate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
getRowsRemainingAfterTerminate() - Method in interface org.apache.hadoop.hive.ql.udf.generic.ISupportStreamingModeForWindowing
 
getRowsSize() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getRowTypeInfo() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getRpcThreadCount() - Method in class org.apache.hive.spark.client.rpc.RpcConfiguration
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
getRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
getRr() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getRunas() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getRunAs() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getRunDisabled() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getRunnable(int) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getRunner() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getRunningTaskCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
getSampleDescExpr() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
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
 
getSargColumnNames(String[], List<OrcProto.Type>, boolean[], boolean) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
getSaslProperties() - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getScale() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns the scale of this Decimal128.
getScale() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
getScale() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 scale = 6;
getScale() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 scale = 6;
getScale() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 scale = 6;
getScale() - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
getScale() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
getScale(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getScale() - Method in class org.apache.hive.service.cli.TypeQualifiers
 
getScaledSelectivity(ColStatistics, ColStatistics) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Scale selectivity based on key range ratio.
getScaleForType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
Need to keep consistent with JdbcColumn.columnScale()
getScanCost(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel
 
getScanCost(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel
 
getScanCost(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel
 
getScanRange(List<IndexSearchCondition>) - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer
Get the scan range that specifies the start/stop keys and/or filters to be applied onto the hbase scan
getSchedulerShims() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
 
getSchema(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getSchema(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getSchema(Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getSchema(StorageDescriptor, StorageDescriptor, Map<String, String>, String, String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
getSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
 
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(boolean) - 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.ShowConfDesc
 
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
 
getSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getSchema() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getSchema(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
getSchema() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getSchema() - Method in class org.apache.hive.jdbc.HiveConnection
 
getSchema() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
getSchemaAsTypeString() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
getSchemaFor(String) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getSchemaFor(File) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getSchemaFor(InputStream) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getSchemaFromCols(Properties, List<String>, List<TypeInfo>, String) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
getSchemaFromFS(String, Configuration) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
Read the schema from the given hdfs url for the schema
getSchemaFromFS(String, Configuration) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
getSchemaFromTableSchema(Properties) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSchemaName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
getSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
getSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getSchemas() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSchemas(String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSchemas(SessionHandle, String, String) - Method in class org.apache.hive.service.cli.CLIService
 
getSchemas(SessionHandle, String, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getSchemas(SessionHandle, String, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
getSchemas(String, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
getSchemas operation handler
getSchemas(String, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetSchemas(TGetSchemasReq, AsyncMethodCallback<TCLIService.AsyncClient.GetSchemas_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetSchemas(TGetSchemasReq, AsyncMethodCallback<TCLIService.AsyncClient.GetSchemas_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetSchemas(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetSchemas(TGetSchemasReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetSchemas(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getSchemas(SessionHandle, String, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
GetSchemasOperation - Class in org.apache.hive.service.cli.operation
GetSchemasOperation.
GetSchemasOperation(HiveSession, String, String) - Constructor for class org.apache.hive.service.cli.operation.GetSchemasOperation
 
getSchemaString() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getSchemaTerm() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSchemaVersion() - Method in class org.apache.hadoop.hive.metastore.model.MVersionTable
 
getScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
getScope() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
getScopeList() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
getScratchColumnTypeMap() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
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
 
getScriptName(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.DerbyCommandParser
 
getScriptName(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MSSQLCommandParser
 
getScriptName(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
getScriptName(String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Parse the DB specific nesting format and extract the inner script name if any
getScriptName(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.OracleCommandParser
 
getScriptName(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
getScriptOutputInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
getSCRProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getSd() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSearchable() - Method in enum org.apache.hive.service.cli.Type
Can you use WHERE based on this type?
getSearchArgument() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getSearchConditions(Configuration) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
getSearchStringEscape() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSecond() - Method in class org.apache.hadoop.hive.common.ObjectPair
 
getSecondarySeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getSeconds() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
getSeconds() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getSeconds(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
Gets seconds stored as integer at bytes[offset]
getSecret() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
getSecretId() - Method in class org.apache.hive.service.cli.HandleIdentifier
 
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(RowSchema, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Create the list of internal columns for select tag of LV
getSelectivity(HiveTableScan, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
getSelectivity(HiveJoin, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
getSelectListInput(Object, ObjectInspector, PTFPartition.PTFPartitionIterator<Object>, int) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
getSelectOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getSelectProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get the ColumnPrunerSelectProc class.
getSelectProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
The Factory method to get the ConstantPropagateSelectProc 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
 
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
 
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
Returns the separator for delimiting items in this array.
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getSeparator() - Static method in class org.apache.hive.beeline.BeeLine
 
getSeparators() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getSeparators() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
getSeparators() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
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.io.AbstractStorageFormatDescriptor
 
getSerde() - Method in class org.apache.hadoop.hive.ql.io.AvroStorageFormatDescriptor
 
getSerde() - Method in class org.apache.hadoop.hive.ql.io.ORCFileStorageFormatDescriptor
 
getSerde() - Method in class org.apache.hadoop.hive.ql.io.ParquetFileStorageFormatDescriptor
 
getSerde() - Method in interface org.apache.hadoop.hive.ql.io.StorageFormatDescriptor
Return the name of the serde as a string or null
getSerde() - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
getSerde() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getSerde() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getSerDe() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the serde.
getSerDeClass() - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
getSerDeClass() - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
getSerDeClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getSerDeClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getSerDeClass() - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
getSerdeClass() - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
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
 
getSerdeClassName() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
 
getSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSerDeInfo() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getSerdeLib() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the serde lib.
getSerDeName() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getSerdeName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSerdeParam(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSerDeParameters() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getSerdeParams() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
getSerdeParams() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getSerdeParams() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getSerdeParams() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getSerdeParams() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Getter for SerDe parameters.
getSerdeParams() - Method in class org.apache.hive.hcatalog.api.HCatTable
Returns parameters such as field delimiter,etc.
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
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
 
getSerdeSeparator() - Method in class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
 
getSerDeStats() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
getSerDeStats() - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
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
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.AbstractDeserializer
Returns statistics collected when serializing
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Returns statistics collected when serializing
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.AbstractSerializer
Returns statistics collected when serializing
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
getSerDeStats() - Method in interface org.apache.hadoop.hive.serde2.Deserializer
Deprecated.
Returns statistics collected when serializing
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Returns the statistics after (de)serialization)
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Returns the statistics after (de)serialization)
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
getSerDeStats() - Method in interface org.apache.hadoop.hive.serde2.Serializer
Deprecated.
Returns statistics collected when serializing
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
getSerDeStats() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
getSerDeStats() - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
 
getSerDeStats() - Method in class org.apache.hive.hcatalog.data.JsonSerDe
 
getSerialization() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
Deprecated.
An Serialization object for objects of type S.
getSerialization() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Deprecated.
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.metastore.api.SerDeInfo
 
getSerializationLib() - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
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.accumulo.serde.AccumuloSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
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
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Returns the Writable class that would be returned by the serialize method.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.AbstractSerializer
Returns the Writable class that would be returned by the serialize method.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Returns the Writable Class after serialization.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Returns the Writable Class after serialization.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
getSerializedClass() - Method in interface org.apache.hadoop.hive.serde2.Serializer
Deprecated.
Returns the Writable class that would be returned by the serialize method.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
getSerializedClass() - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
 
getSerializedClass() - Method in class org.apache.hive.hcatalog.data.JsonSerDe
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getSerializedSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
getSerializedValue(ObjectInspector, Object, ByteStream.Output, ColumnMapping) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
Compute the serialized value from the given element and object inspectors.
getSerializer() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
getSerName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
Getter for HCatalog Server's URL.
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
getServer() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getServerIPAddress() - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getServerPrincipal(String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
getServerProtocolVersion() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getServerSocket(String, int) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
getServerSSLSocket(String, int, String, String, List<String>) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
getService() - Method in class org.apache.hive.service.cli.thrift.EmbeddedThriftBinaryCLIService
 
getServiceName() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
getServiceName() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
getServiceName() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.KerberosNameShim
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
Getter for the Kerberos principal of the HCatalog service.
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
getServicePrincipal() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getServices() - Method in class org.apache.hive.service.CompositeService
 
getServiceState() - Method in class org.apache.hive.service.AbstractService
 
getServiceState() - Method in class org.apache.hive.service.FilterService
 
getServiceState() - Method in interface org.apache.hive.service.Service
Get the current service state
getServiceUGI() - Method in class org.apache.hive.service.cli.CLIService
 
getSession(SparkSession, HiveConf, boolean) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager
Get a valid SparkSession.
getSession(SparkSession, HiveConf, boolean) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
If the existingSession can be reused return it.
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
 
getSession() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getSession() - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
getSession(SessionHandle) - Method in class org.apache.hive.service.cli.session.SessionManager
 
getSessionConf() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getSessionConf() - Method in interface org.apache.hive.service.cli.session.HiveSessionHookContext
Retrieve session conf
getSessionConf() - Method in class org.apache.hive.service.cli.session.HiveSessionHookContextImpl
 
getSessionHandle() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getSessionHandle() - Method in interface org.apache.hive.service.cli.session.HiveSessionHookContext
Retrieve handle for the session
getSessionHandle() - Method in class org.apache.hive.service.cli.session.HiveSessionHookContextImpl
 
getSessionHandle() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
getSessionId() - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
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
 
getSessionId() - Method in class org.apache.hive.service.cli.SessionHandle
 
getSessionId() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
getSessionManager() - Method in class org.apache.hive.service.cli.CLIService
 
getSessionManager() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Get the session manager for the session
getSessionManager() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getSessionName() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
The session name is an identifier to recognize the session.
getSessionSpecifiedClassLoader() - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
get session specified class loader and get current class loader if fall
getSessionState() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getSessionState() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getSessionString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
getSessionString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext
 
getSessionUgi() - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
getSessionUser() - Method in interface org.apache.hive.service.cli.session.HiveSessionHookContext
The get the username starting the session
getSessionUser() - Method in class org.apache.hive.service.cli.session.HiveSessionHookContextImpl
 
getSessionVars() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getSettableExpressionWriters(SettableStructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
 
getSharedSDPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getShort() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct.SingleFieldGetter
 
getShort(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the short value out of a primitive object.
getShort(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getShort(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getShort(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getShort(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getShort(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getShortName() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
getShortName() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
getShortName() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.KerberosNameShim
 
getShortValue() - Method in class org.apache.hive.service.cli.GetInfoValue
 
getShortVersion() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the Hive short version, with major/minor/change version numbers.
getShowColumnsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowCompactionsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowConfDesc() - 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
 
getShrinkedLength() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
getShuffleType() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
getShuffleType() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
getSidefileKVContainer() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
getSignature() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getSignum() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns the signum of this Decimal128.
getSingleChild(Operator<?>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSingleChild(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSingleChild(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSingleParent(Operator<?>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSingleParent(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSingleParent(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
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
 
getSIntString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
getSIntStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
getSIntStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
getSize() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
get number of bytes to store the keyBuffer.
getSize(HiveConf, Table) - Method in class org.apache.hadoop.hive.ql.optimizer.SizeBasedBigTableSelectorForAutoSMJ
 
getSize(HiveConf, Partition) - Method in class org.apache.hadoop.hive.ql.optimizer.SizeBasedBigTableSelectorForAutoSMJ
 
getSize() - Method in class org.apache.hive.service.cli.RowBasedSet
 
getSize() - Method in class org.apache.hive.service.cli.TableSchema
 
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.metastore.api.SkewedInfo
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
getSkewedColNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getSkewedColNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
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.metastore.api.SkewedInfo
 
getSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedColValueLocationMapsSize() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
getSkewedColValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getSkewedColValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
getSkewedInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSkewedInfo() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedLocations() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSkewedValueFromASTNode(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Given a ASTNode, return list of values.
getSkewedValuesDirNames() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getSkewedValuesFromASTNode(Node) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Retrieve skewed values from ASTNode.
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
 
getSkipTag() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getSmallIntValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSmbMapJoinOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getSnapshotSplit() - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
getSocket() - Method in class org.apache.hadoop.hive.thrift.TUGIContainingTransport
If the underlying TTransport is an instance of TSocket, it returns the Socket object which it contains.
getSocketTransport(String, int, int) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
getSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
getSortableSortOrders() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
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.metastore.api.StorageDescriptor
 
getSortCols() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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.BaseWork
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
getSortCols() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getSortCols() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the sort columns.
getSortCols() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the sort columns.
getSortColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSortColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
getSortedInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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
 
getSortedTags(JoinOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
getSortOrder() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
getSortOrders() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getSortTraitSet(RelOptCluster, RelTraitSet, RelCollation) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.TraitsUtil
 
getSource() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getSource() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
getSource() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSource_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
getSource_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
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
 
getSourceTableInputFormat() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
getSourceTask() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getSparkConf() - Method in interface org.apache.hadoop.hive.ql.exec.spark.HiveSparkClient
 
getSparkConf() - Method in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
getSparkConf() - Method in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
getSparkConfigUpdated() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getSparkCounterGroups() - Method in class org.apache.hive.spark.counter.SparkCounters
 
getSparkCounters() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkTask
 
getSparkCounters() - Method in interface org.apache.hive.spark.client.JobHandle
Get the SparkCounters for this job.
getSparkCounters() - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
getSparkJobIds() - Method in interface org.apache.hive.spark.client.JobHandle
Get corresponding spark job IDs for this job.
getSparkJobStatus() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobRef
 
getSparkJobStatus() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobRef
 
getSparkJobStatus() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobRef
 
getSparkSession(HiveConf, SparkSessionManager) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
getSparkSession() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getSparkStageProgress() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getSparkStageProgress() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getSparkStageProgress() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getSparkStatistics() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getSparkStatistics() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getSparkStatistics() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getSparkTasks(List<Task<? extends Serializable>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
getSplit(int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getSplit(InputSplit, JobConf) - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
gets a ParquetInputSplit corresponding to a split given by Hive
getSplitCount(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
getSplitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
getSplitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
getSplitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
getSplitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
getSplitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
getSplitCount() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getSplitCountWithoutRepartition(HiveJoin) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
getSplitCountWithRepartition(HiveJoin) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.hbase.HiveHBaseTableSnapshotInputFormat
 
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.
getSplits(JobConf, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
getSplits(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceInputFormat
 
getSplits(JobContext) - Method in class org.apache.hive.hcatalog.templeton.tool.SingleInputFormat
 
getSplitSample() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSPPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getSQLKeywords() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSqlOp() - Method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
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
 
getSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getSqlState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getSqlState() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getSQLStateType() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSqlTableType() - Method in class org.apache.hive.jdbc.JdbcTable
 
getSQLXML(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getSQLXML(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getSQLXML(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getSQLXML(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getSrcChecksum() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the checksum of the source files from which Hive was built.
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
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AddPartitionReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterPartitionReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterTableReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.CreateTableReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropDatabaseReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropPartitionReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropTableReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.exim.InsertReplicationTask
 
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.NoopReplicationTask
Returns a list of commands to send to a hive driver on the source warehouse
getSrcWhCommands() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Returns a Iterable to send to a hive driver on the source warehouse If you *need* a List instead, you can use guava's ImmutableList.copyOf(iterable) or Lists.newArrayList(iterable) to get the underlying list, but this defeats the purpose of making this interface an Iterable rather than a List, since it is very likely that the number of Commands returned here will cause your process to run OOM.
getSSIsSilent() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.getIsSilent().
getSSLSocket(String, int, int) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
getSSLSocket(String, int, int, String, String) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
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
 
getStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageID() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getStageIds() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getStageIds() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getStageIds() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getStageIds(int) - Method in class org.apache.hive.spark.client.MetricsCollection
 
getStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageMetrics(int, int) - Method in class org.apache.hive.spark.client.MetricsCollection
 
getStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStagingDirectory(String) - Method in interface org.apache.hive.hcatalog.api.repl.StagingDirectoryProvider
Return a temporary staging directory for a given key
getStagingDirectory(String) - Method in class org.apache.hive.hcatalog.api.repl.StagingDirectoryProvider.TrivialImpl
 
getStandardConstantListObjectInspector(ObjectInspector, List<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardConstantMapObjectInspector(ObjectInspector, ObjectInspector, Map<?, ?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardDeviationTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getStandardDisplayString(String, String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getStandardDisplayString(String, String[], String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getStandardJavaObjectInspectorFromTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Returns the standard object inspector that can be used to translate an object of that typeInfo to a standard object type.
getStandardListObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardMapObjectInspector(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the corresponding standard ObjectInspector for an ObjectInspector.
getStandardObjectInspector(ObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStandardObjectInspectorFromTypeInfo(TypeInfo) - Static method in class org.apache.hive.hcatalog.data.HCatRecordObjectInspectorFactory
 
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
 
getStandardStructFieldRef(String, List<? extends StructField>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStandardStructObjectInspector(List<String>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
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.
getStandardStructTypeName(StructObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStandardUnionObjectInspector(List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardUnionTypeName(UnionObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStandardWritableObjectInspectorFromTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Returns the standard object inspector that can be used to translate an object of that typeInfo to a standard object type.
getStart() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
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.orc.OrcFileStripeMergeRecordReader
 
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
 
getStart() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
getStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getStartForGroupBy(ReduceSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
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
 
getStartOffset() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
getStartOffset() - Method in class org.apache.hive.service.cli.RowBasedSet
 
getStartOffset() - Method in interface org.apache.hive.service.cli.RowSet
 
getStartOffsets() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the startoffsets of the files in the split.
getStartRow() - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
getStartRowOffset() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
getStartTime(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getStartTime() - Method in class org.apache.hive.service.AbstractService
 
getStartTime() - Method in class org.apache.hive.service.FilterService
 
getStartTime() - Method in interface org.apache.hive.service.Service
Get the service start time
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.
getState() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
getState() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getState() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getState() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
getState() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
getState() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
getState() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobStatus
 
getState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getState() - Method in class org.apache.hive.service.cli.OperationStatus
 
getState() - Method in interface org.apache.hive.spark.client.JobHandle
Return the current state of the job.
getStatement() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getStatement() - Method in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
getStatement() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
getStatFromMap(String, Map<String, String>) - Static method in class org.apache.hadoop.hive.hbase.HBaseStatsUtils
Retrieves the value for a particular stat from the published map.
getStaticSpec() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getStatisticGroups() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatistics
 
getStatistics() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getStatistics() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticGroup
 
getStatistics(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatistics(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatistics(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
getStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
optional .orc.proto.ColumnStatistics statistics = 2;
getStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
optional .orc.proto.ColumnStatistics statistics = 2;
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.io.orc.ReaderImpl
 
getStatistics() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
getStatistics() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
getStatistics(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
Get statistics about the data to be loaded.
getStatisticsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
getStatisticsBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
getStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
optional .orc.proto.ColumnStatistics statistics = 2;
getStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
optional .orc.proto.ColumnStatistics statistics = 2;
getStatisticsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.ColumnStatistics statistics = 7;
getStatisticsOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.ColumnStatistics statistics = 7;
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
getStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
getStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
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
getStatsData() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
getStatsDesc() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
getStatsObj() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
getStatsObjIterator() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
getStatsObjSize() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
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
 
getStatus() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Used to represent to the user and other components what state the HWISessionItem is in.
getStatus() - Method in class org.apache.hadoop.hive.metastore.events.ListenerEvent
 
getStatus() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getStatus() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
getStatus() - Method in class org.apache.hive.service.cli.operation.Operation
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
getStatus() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
getStatusCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
getStopProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
getStopRow() - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
getStorage(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.JobState
Get an open instance of the selected storage class.
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.parse.StorageFormat
 
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
 
getStorageHandler() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getStorageHandler() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the storage handler.
getStorageHandler() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the storage handler.
getStorageHandler(Configuration, StorerInfo) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Create an instance of a storage handler defined in storerInfo.
getStorageHandler(Configuration, PartInfo) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getStorageHandler(Configuration, String, String, String, String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Create an instance of a storage handler.
getStorageHandlerClass() - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
getStorageHandlerClassName() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
 
getStorageInstance(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.JobState
Get an instance of the selected storage class.
getStoragePolicyShim(FileSystem) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getStoragePolicyShim(FileSystem) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getStoragePolicyShim(FileSystem) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
obtain a storage policy shim associated with the filesystem.
getStoredStats() - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
getStorerInfo() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
getStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getStreamAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getStreamAliases() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getStreamingInput() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getStreamingSide() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
getStreamLength() - Method in class org.apache.hadoop.hive.ql.io.orc.InStream
 
getStreamName() - Method in class org.apache.hadoop.hive.ql.io.orc.InStream
 
getStreams(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreams(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.Stream streams = 1;
getStreams(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.Stream streams = 1;
getStreamsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.Stream streams = 1;
getStreamsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.Stream streams = 1;
getStreamsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.Stream streams = 1;
getStreamsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
repeated .orc.proto.Stream streams = 1;
getStreamsOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
repeated .orc.proto.Stream streams = 1;
getStrExprProcessor() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get StrExprProcessor.
getString(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the String value out of a primitive object.
getString(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getString(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getString(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getString(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getString(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getStringCollection(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Returns a collection of strings.
getStringConverter(ObjectInspector[], int, String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSoundex
 
getStringFormTokenCache() - Static method in class org.apache.hive.hcatalog.templeton.tool.DelegationTokenCache
 
getStringFunctions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getStrings(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Returns an arraylist of strings.
getStringStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.StringStatistics stringStatistics = 4;
getStringStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getStringVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getStringVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
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
 
getStringValue(GenericUDF.DeferredObject[], int, ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getStringValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getStringValue() - Method in class org.apache.hive.service.cli.GetInfoValue
 
getStringValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getStringValue() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
getStripeInformation() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
getStripes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.StripeInformation stripes = 3;
getStripes(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.StripeInformation stripes = 3;
getStripes() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the list of stripes.
getStripes() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getStripesBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.StripeInformation stripes = 3;
getStripesCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.StripeInformation stripes = 3;
getStripesList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.StripeInformation stripes = 3;
getStripesOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.StripeInformation stripes = 3;
getStripeStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.Metadata
Return list of stripe level column statistics
getStripeStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
getStripeStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStats(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.MetadataOrBuilder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.MetadataOrBuilder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.MetadataOrBuilder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.MetadataOrBuilder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStripeStatsOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.MetadataOrBuilder
repeated .orc.proto.StripeStatistics stripeStats = 1;
getStrippedValue() - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
getStrippedValue() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
getStruct(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getStructDesc() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
getStructDesc() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
getStructDesc() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
getStructDesc() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
getStructDesc() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
getStructDesc() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
getStructDesc() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
getStructDesc() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getStructDesc() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
getStructEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
returns null for data = null.
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getStructFieldData(Object, StructField) - Method in class org.apache.hive.hcatalog.data.HCatRecordObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
getStructFieldRef(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
Look up a field.
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
returns null for data = null.
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hive.hcatalog.data.HCatRecordObjectInspector
 
getStructFieldTypeInfo(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getStructSchemaBuilder() - Static method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
getStructSize(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStructSubSchema() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getStructTypeInfo(List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getSubmittedId() - Method in class org.apache.hive.hcatalog.templeton.tool.TempletonControllerJob
 
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() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get SubQueryExprProcessor.
getSubQueryPredicateDef() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getSubstitute(Configuration, String) - Method in class org.apache.hadoop.hive.conf.SystemVariables
 
getSubstitute(Configuration, String) - Method in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
getSubtypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
getSubtypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated uint32 subtypes = 2 [packed = true];
getSubtypes(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated uint32 subtypes = 2 [packed = true];
getSubtypesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
getSubtypesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated uint32 subtypes = 2 [packed = true];
getSubtypesCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated uint32 subtypes = 2 [packed = true];
getSubtypesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
getSubtypesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
repeated uint32 subtypes = 2 [packed = true];
getSubtypesList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
repeated uint32 subtypes = 2 [packed = true];
getSucceededTaskCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
getSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
GetSuffix(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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 class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
optional sint64 sum = 1;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
optional sint64 sum = 1;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatisticsOrBuilder
optional sint64 sum = 1;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string sum = 3;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double sum = 3;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 sum = 3;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional sint64 sum = 3;
getSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional sint64 sum = 3;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional sint64 sum = 3;
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the total length of all strings
getSumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
getSumBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string sum = 3;
getSumBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string sum = 3;
getSumFieldJavaObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
getSumFieldJavaObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
getSumFieldJavaObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
getSumFieldWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
getSumFieldWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
getSumFieldWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
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
getSuperTables(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSuperTypes(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getSupportedScope() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
getSupportedStatistics() - Static method in class org.apache.hadoop.hive.hbase.HBaseStatsUtils
Returns the set of supported statistics
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
 
getSymbolFunction() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolParser
 
getSystemFunctions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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.metastore.events.AddPartitionEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.AlterPartitionEvent
Get the table this partition is in
getTable() - Method in class org.apache.hadoop.hive.metastore.events.CreateTableEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.DropPartitionEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.DropTableEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.InsertEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.LoadPartitionDoneEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.PreCreateTableEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.PreDropPartitionEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.PreDropTableEvent
 
getTable() - Method in class org.apache.hadoop.hive.metastore.events.PreReadTableEvent
 
getTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTable(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated.
getTable(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated.
As of release 0.6.0 replaced by IMetaStoreClient.getTable(String, String). This method will be removed in release 0.7.0.
getTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a table object.
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getTable(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
getTable(String[]) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getTable(String[], boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getTable(String) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getTable(String, boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getTable(String, String, boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getTable() - Method in class org.apache.hadoop.hive.ql.parse.EximUtil.ReadMetaData
 
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.AppMasterEventDesc
 
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.FileSinkDesc
 
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
 
getTable(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Gets the table.
getTable(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
getTable(IMetaStoreClient, String, String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.AddPartitionMessage
Getter for name of table (where partitions are added).
getTable() - Method in class org.apache.hive.hcatalog.messaging.AlterPartitionMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.AlterTableMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.CreateTableMessage
Getter for the name of table created in HCatalog.
getTable() - Method in class org.apache.hive.hcatalog.messaging.DropPartitionMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.DropTableMessage
Getter for the name of the table being dropped.
getTable() - Method in class org.apache.hive.hcatalog.messaging.InsertMessage
Getter for the name of the table being insert into.
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
getTable() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
getTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
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.optimizer.calcite.reloperators.HiveTableScan
 
getTableCatalog() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getTableCatalog() - Method in class org.apache.hive.jdbc.JdbcTable
 
getTableColumns() - Method in class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
 
getTableColumnStatistics(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get table column statistics given dbName, tableName and multiple colName-s
getTableColumnStatistics(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get table column statistics given dbName, tableName and multiple colName-s
getTableColumnStatistics(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTableColumnStatistics(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Returns the relevant column statistics for a given column in a given table in a given database if such statistics exist.
getTableColumnStatistics(String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getTableColumnStatistics(String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
Get table column statistics given dbName, tableName and multiple colName-s
getTableColumnStatisticsDesc(MTableColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
getTableColumnStatisticsInternal(String, String, List<String>, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTableColumnStatisticsObj(MTableColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
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
 
getTableInfo() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Gets the table's meta information
getTableInfo() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getTableInfo() - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Gets the HCatalog table information.
getTableInformation(Table) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getTableLocation() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
getTableMetadata(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getTableMetadata() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getTableName(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
getTableName(TableDesc) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
getTableName(RangeInputSplit) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
Reflection to work around Accumulo 1.5 and 1.6 incompatibilities.
getTablename() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
getTablename() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
getTablename() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
getTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.events.PreAlterPartitionEvent
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.events.PreLoadPartitionDoneEvent
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Getter for name of the table.
getTableName() - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Getter for the name of the table.
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
getTableName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Accepts qualified name which is in the form of dbname.tablename and returns tablename from it
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.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
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
 
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
Deprecated.
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the table name.
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec
Getter for TableName of this HCatPartitionSpec.
getTableName() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the table name.
getTableName() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
Gets the value of tableName
getTableName() - Method in class org.apache.hive.hcatalog.mapreduce.InputJobInfo
Gets the value of tableName
getTableName() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
getTableName(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
getTableName() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getTableName() - Method in class org.apache.hive.jdbc.JdbcTable
 
getTableName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
getTableName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getTableNames() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getTableNames() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getTableObjectsByName(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
getTableObjectsByName(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getTableObjectsByName(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTableObjectsByName(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTableObjectsByName(String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
getTablePath(String, String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getTablePath(Database, String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getTablePrivileges(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getTablePrivilegeSet(String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTablePrivilegeSet(String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTableProperties() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getTableProperties() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getTableRowSize() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getTables(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all tables in the specified database that satisfy the supplied table name pattern.
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all tables in the specified database that satisfy the supplied table name pattern.
getTables(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTables(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
getTables(String, String, String, String[]) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getTables(SessionHandle, String, String, String, List<String>) - Method in class org.apache.hive.service.cli.CLIService
 
getTables(SessionHandle, String, String, String, List<String>) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getTables(SessionHandle, String, String, String, List<String>) - Method in interface org.apache.hive.service.cli.ICLIService
 
getTables(String, String, String, List<String>) - Method in interface org.apache.hive.service.cli.session.HiveSession
getTables operation handler
getTables(String, String, String, List<String>) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetTables(TGetTablesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTables_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetTables(TGetTablesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTables_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetTables(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetTables(TGetTablesReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetTables(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getTables(SessionHandle, String, String, String, List<String>) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getTableSample() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
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.
getTableScan() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
getTableScanMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getTableScanOperator() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
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
 
getTableSchema(Configuration) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
Gets the HCatTable schema for the table specified in the HCatInputFormat.setInput call on the specified job context.
getTableSchema(Configuration) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
Gets the table schema for the table specified in the HCatOutputFormat.setOutput call on the specified job context.
getTableSchema() - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
Gets the table schema.
getTableSchemaWithPtnCols(Table) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
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
 
GetTablesOperation - Class in org.apache.hive.service.cli.operation
GetTablesOperation.
GetTablesOperation(HiveSession, String, String, String, List<String>) - Constructor for class org.apache.hive.service.cli.operation.GetTablesOperation
 
getTableSpec() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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 analyze 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
 
getTableSplit() - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
getTableStats() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
getTableStatsIterator() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
getTableStatsSize() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
getTableToColumnAccessMap() - Method in class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
 
getTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getTableType() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getTableType() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getTabletype() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the tableType.
getTableTypeMapping(String) - Static method in class org.apache.hive.service.cli.operation.TableTypeMappingFactory
 
getTableTypeNames() - Method in class org.apache.hive.service.cli.operation.ClassicTableTypeMapping
 
getTableTypeNames() - Method in class org.apache.hive.service.cli.operation.HiveTableTypeMapping
 
getTableTypeNames() - Method in interface org.apache.hive.service.cli.operation.TableTypeMapping
Get all the table types of this mapping
getTableTypes() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getTableTypes(SessionHandle) - Method in class org.apache.hive.service.cli.CLIService
 
getTableTypes(SessionHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getTableTypes(SessionHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
getTableTypes() - Method in interface org.apache.hive.service.cli.session.HiveSession
getTableTypes operation handler
getTableTypes() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetTableTypes(TGetTableTypesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTableTypes_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetTableTypes(TGetTableTypesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTableTypes_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetTableTypes(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetTableTypes(TGetTableTypesReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
getTableTypes() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
GetTableTypes(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getTableTypes(SessionHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
getTableTypesIterator() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
GetTableTypesOperation - Class in org.apache.hive.service.cli.operation
GetTableTypesOperation.
GetTableTypesOperation(HiveSession) - Constructor for class org.apache.hive.service.cli.operation.GetTableTypesOperation
 
getTableTypesSize() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
getTableVisibilityLabel() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
Extracts the table property to allow a custom ColumnVisibility label to be set on updates to be written to an Accumulo table.
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
 
getTabSize(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getTag() - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator.Handler
 
getTag() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getTag() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTag() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Get the tag of the union
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getTag() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
Get the set field's tag
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryUnionObjectInspector
Return the tag of the object.
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
Return the tag of the object.
getTag() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getTag() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObject
Get the tag of the union.
getTag(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Return the tag of the object.
getTagForOperator(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
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
 
getTail() - Method in class org.apache.hadoop.hive.common.DiskRangeList.DiskRangeListCreateHelper
 
getTargetColumnName() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
getTargetDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getTargetDirs() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getTargets(CommonJoinOperator<JoinDesc>) - Static method in class org.apache.hadoop.hive.ql.ppd.PredicateTransitivePropagate
 
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
 
getTaskAttemptContext(String, TaskAttemptContext) - Static method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
Get the TaskAttemptContext with the related OutputFormat configuration populated given the alias and the actual TaskAttemptContext
getTaskAttemptLogUrl(JobConf, String, String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getTaskAttemptLogUrl(JobConf, String, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getTaskAttemptLogUrl(JobConf, String, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Constructs and Returns TaskAttempt Log Url or null if the TaskLogServlet is not available
getTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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.
getTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskIdFromFilename(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get the task id from the filename.
getTaskIds(int, int) - Method in class org.apache.hive.spark.client.MetricsCollection
 
getTaskInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTaskListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTaskListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTaskMetrics(int, int, long) - Method in class org.apache.hive.spark.client.MetricsCollection
 
getTaskNumbers() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
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
 
getTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
getTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
getTbl() - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
getTbl_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
getTbl_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
getTbl_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
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
 
getTblName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
getTblName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
getTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
getTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
getTblName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
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
 
getTblProps() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
Deprecated.
getTblProps() - Method in class org.apache.hive.hcatalog.api.HCatTable
Gets the table props.
getTemplate() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getTemplateFile() - Method in class org.apache.hadoop.hive.ant.GenHiveTemplate
 
getTemplatePath() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getTempletonDir() - Static method in class org.apache.hive.hcatalog.templeton.AppConfig
 
getTemporaryFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getTempTableColStats() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTempTables() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTempTableSpace(Configuration) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTempTableSpace() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTerminalWidth() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
NOTE: Use this method only if isUnixTerminal is true.
getText(ASTNode) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getText() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
getTextUtfLength(Text) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
getTextValue() - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
Access to the internal Text member.
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
getTezProcessorContext() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
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
 
getThreadRawStoreMap() - Static method in class org.apache.hive.service.server.ThreadFactoryWithGarbageCleanup
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TRow._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
 
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
getThriftSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getThriftSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getThriftSchema() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getTime(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTime(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTime(int, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTime(String, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTime(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTime(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTime(int, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTime(String, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTimeCounter() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
 
getTimeDateFunctions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getTimeInSeconds() - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
getTimeNanoSec(Timestamp) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
getTimeOfDayNanos() - Method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
getTimestamp(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getTimestamp(NanoTime, boolean) - Static method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTimeUtils
 
getTimestamp() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadTimestampResults
 
getTimestamp() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getTimestamp(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getTimestamp(Object, PrimitiveObjectInspector, boolean) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
getTimestamp(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.HCatEventMessage
Getter for the timestamp associated with the operation.
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
getTimestamp() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
getTimestamp(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTimestamp(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTimestamp(int, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTimestamp(String, Calendar) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getTimestamp(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTimestamp(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTimestamp(int, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTimestamp(String, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getTimestampColumnMapping() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getTimestampColumnName() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
 
getTimestampField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthLong
 
getTimestampField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getTimestampField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampLong
 
getTimestampField(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearLong
 
getTimestampFormats() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
getTimestampFormats() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
getTimestampFormats() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
getTimestampFormats() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
getTimestampIndex() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
getTimestampIndex() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getTimestampMapping() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
getTimestampParser() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
getTimestampStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatisticsBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatisticsOrBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampStatisticsOrBuilder() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
getTimestampValue(GenericUDF.DeferredObject[], int, ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getTimeUnit() - Method in class org.apache.hadoop.hive.conf.Validator.TimeValidator
 
getTimeVar(Configuration, HiveConf.ConfVars, TimeUnit) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getTimeVar(HiveConf.ConfVars, TimeUnit) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getTmpHDFSPath() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
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(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getToken(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getToken() - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
 
getToken(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Get the specific Token.
getToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
getToken(DelegationTokenIdentifier) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Get token.
getToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
getToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
getToken_owner() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
getToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
getToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
getTokenIdentifier() - Method in class org.apache.hadoop.hive.metastore.model.MDelegationToken
 
getTokenIdentifier(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
getTokenNames() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
getTokenPath() - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
The file where we store the auth token
getTokenRewriteStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getTokenStore(Configuration) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getTokenStr() - Method in class org.apache.hadoop.hive.metastore.model.MDelegationToken
 
getTokenStrForm() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTokenStrForm() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getTokenStrForm(String) - Static method in class org.apache.hadoop.hive.shims.Utils
Get the string form of the token given a token signature.
getTokenTransport(String, String, TTransport, Map<String, String>) - Static method in class org.apache.hive.service.auth.KerberosSaslHelper
 
getToPath() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
getTopLevelSelect(RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
Get top level select starting from root.
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
 
getToSpillPartitionId() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Gets the partition Id into which to spill the big table row
getTotalBlocksFetched() - Method in class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
Number of blocks fetched in shuffle by tasks (remote or local).
getTotalFiles() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getTotalInMemRowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
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
 
getTotalLength(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
getTotalMonths() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
getTotalSeconds() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
Returns days/hours/minutes all converted into seconds.
getTotalSize(Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get total size of a give table
getTotalTaskCount() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
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.
getTrackingJobs(Configuration, CuratorFramework) - Static method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
 
getTraitDef() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
getTraits() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
getTraits() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
getTransactionId() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
What was the original transaction id for the last row?
getTransactionId() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getTransactionIsolation() - Method in class org.apache.hive.jdbc.HiveConnection
 
getTransformProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getTransport(TTransport) - Method in class org.apache.hadoop.hive.thrift.TUGIContainingTransport.Factory
Get a new TUGIContainingTransport instance, or reuse the existing one if a TUGIContainingTransport has already been created before using the given TTransport as an underlying transport.
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.adminOptionFor_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixSetOwner_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterIndexStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectModeMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementChangeColPosition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementPartitionKeyType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddCol_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddPartitions_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddPartitionsElement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixArchive_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixBucketNum_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixClusterbySortby_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixCompact_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixDropPartitions_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixExchangePartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixFileFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixMergeFiles_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProtectMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRename_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenameCol_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenamePart_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixSerdeProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixSkewedby_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixStatsPart_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixTouch_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUnArchive_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUpdateStatsCol_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTableStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffixSkewedLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.analyzeStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.autoRebuild_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.body_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.colType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.colTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnAssignmentClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameCommentList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrder_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrderList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnRefOrder_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createFunctionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createIndexStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createMacroStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createRoleStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createTableStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createViewStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.cteStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.databaseComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dbLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dbProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dbPropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ddlStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.deleteStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.descStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.destination_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropFunctionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropIndexStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropMacroStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropRoleStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropTableStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropViewStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.execStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.explainOption_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.explainStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.exportStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.fileFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.fromStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.grantOptionFor_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.grantPrivileges_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.grantRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ifExists_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ifNotExists_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ignoreProtection_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.importStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesPrefixed_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexTblName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.insertClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.keyProperty_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.keyValueProperty_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.limitClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.listType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.loadStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.lockDatabase_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.lockMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.lockStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.mapType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.metastoreCheck_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.orReplace_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.partitionLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.partTypeExpr_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.primitiveType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.principalName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.principalSpecification_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeIncludeColObject_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeObject_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privlegeDef_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privObject_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privObjectCols_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatementExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatementExpressionBody_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.recordReader_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.recordWriter_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.regularBody_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.reloadFunctionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.replicationClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.resource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.resourceList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.resourceType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.restrictOrCascade_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.revokePrivileges_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.revokeRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatDelimited_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatSerde_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectStatementWithCTE_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.setColumnsClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.setOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.setOpSelectStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.setRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showCurrentRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showFunctionIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showGrants_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showRoleGrants_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showRolePrincipals_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showRoles_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showStmtIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.simpleSelectStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.singleFromStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValue_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValuePair_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValuePairList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValues_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocationMap_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocations_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocationsList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedValueElement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.skewedValueLocationElement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.statement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.storedAsDirs_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.structType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.switchDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableBuckets_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableFileFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartitionPrefix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesPrefixed_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatCollItemsIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatFieldIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatLinesIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatMapKeysIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowNullFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableSkewed_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tabTypeExpr_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.truncateTableStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.type_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.unionType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.unlockDatabase_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.unlockStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.updateStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.viewPartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.withAdminOption_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.withClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.withGrantOption_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.aliasList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.expressionList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.fromClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.fromSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.joinSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.joinToken_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.lateralView_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitionedTableFunction_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitioningSpec_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitionTableFunctionSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.searchCondition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.splitSample_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.subQuerySource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableAlias_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableAllColumns_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableBucketSample_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableNameColList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableOrColumn_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableSample_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinExpr_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinToken_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valueRowConstructor_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valuesClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valuesTableConstructor_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.viewName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.virtualTableSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.whereClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.atomExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.booleanValue_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.caseExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.castExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.charSetStringLiteral_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.clusterByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.columnRefOrderInParenthese_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.columnRefOrderNotInParenthese_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.constant_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dateLiteral_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.descFuncNames_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.distributeByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionSpec_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionVal_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressions_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressionsInParenthese_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressionsNotInParenthese_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.function_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.functionIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.functionName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingExpressionSingle_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingSetExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingSetExpressionMultiple_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.havingClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.havingCondition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.identifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.intervalLiteral_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.intervalQualifiers_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.nonReserved_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.nullCondition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.orderByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionSpec_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionVal_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAmpersandExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAmpersandOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAndExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAndOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseOrExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseOrOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseXorExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseXorOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualNegatableOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceFieldExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceNotExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceNotOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceOrExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceOrOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedencePlusExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedencePlusOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceStarExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceStarOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnaryOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnaryPrefixExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnarySuffixExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.principalIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sortByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsCastFunctionName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.stringLiteralSequence_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.subQueryExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sysFuncNames_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.tableOrPartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.timestampLiteral_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.whenExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintArgName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintArgs_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintItem_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectExpressionList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectItem_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectTrfmClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.trfmClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_clause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_defn_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_boundary_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_start_boundary_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_range_expression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_specification_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_value_expression_return
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
getTrimmedStringCollection(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Splits a comma separated value String, trimming leading and trailing whitespace on each value.
getTrimmedStrings(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Splits a comma separated value String, trimming leading and trailing whitespace on each value.
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
 
getTuples() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
getTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
getTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
getTxn_ids() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
getTxn_idsIterator() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
getTxn_idsSize() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getTxnid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
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.
getTxnMgr() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTxns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
getTyp() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getType(int) - Static method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordReader
 
getType() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Get the type code embedded in the first byte.
getType() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
getType(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getType() - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
getType() - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
getType(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getType(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
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.ColumnStatsUpdateTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
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.ExplainSQRewriteTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
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.OrcFileMergeOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
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.spark.SparkTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
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() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
getType(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
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.merge.MergeFileTask
 
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 by the file format.
getType() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
getType(RelOptCluster, List<ColumnInfo>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
Convert Hive Types To Calcite Types
getType(RelOptCluster, RowResolver, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.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
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
getType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
getType() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
Deprecated.
as of 0.13, slated for removal with 0.15 use HCatFieldSchema.getTypeInfo() instead
getType() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getType() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
getType() - Method in class org.apache.hive.jdbc.JdbcColumn
 
getType() - Method in class org.apache.hive.jdbc.JdbcTable
 
getType() - Method in class org.apache.hive.service.cli.Column
 
getType() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getType() - Method in class org.apache.hive.service.cli.operation.Operation
 
getType() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
getType(TTypeId) - Static method in enum org.apache.hive.service.cli.Type
 
getType(String) - Static method in enum org.apache.hive.service.cli.Type
 
getType() - Method in class org.apache.hive.service.cli.TypeDescriptor
 
getType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getType1() - Method in class org.apache.hadoop.hive.metastore.model.MType
 
getType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getType2() - Method in class org.apache.hadoop.hive.metastore.model.MType
 
getTypeAll(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTypeArray() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
getTypeCheckCtx() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getTypeClassName() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
getTypeDesc() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
getTypeDescriptor() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getTypeEntryFromPrimitiveCategory(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the typeName from a Java Primitive Type or Java PrimitiveClass.
getTypeEntryFromPrimitiveJava(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the TypeEntry for a Java Primitive Type or Java PrimitiveClass.
getTypeEntryFromPrimitiveJavaClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the TypeEntry for a Java Primitive Type or Java PrimitiveClass.
getTypeEntryFromPrimitiveJavaType(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the TypeEntry for a Java Primitive Type or Java PrimitiveClass.
getTypeEntryFromPrimitiveWritableClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the TypeEntry for a Primitive Writable Class.
getTypeEntryFromTypeName(String) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the TypeEntry for the given base type name (int, varchar, etc).
getTypeExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
getTypeForHiveColumn(String) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
getTypeForName(String) - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
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
 
getTypeInfo() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
 
getTypeInfo() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
 
getTypeInfo() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
May return null
getTypeInfo() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getTypeInfo(SessionHandle) - Method in class org.apache.hive.service.cli.CLIService
 
getTypeInfo(SessionHandle) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
getTypeInfo(SessionHandle) - Method in interface org.apache.hive.service.cli.ICLIService
 
getTypeInfo() - Method in interface org.apache.hive.service.cli.session.HiveSession
getTypeInfo operation handler
getTypeInfo() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
GetTypeInfo(TGetTypeInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTypeInfo_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
GetTypeInfo(TGetTypeInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTypeInfo_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
GetTypeInfo(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
GetTypeInfo(TGetTypeInfoReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
GetTypeInfo(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
getTypeInfo(SessionHandle) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
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.
getTypeInfoFromObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Get the TypeInfo object from the ObjectInspector object by recursively going into the ObjectInspector structure.
getTypeInfoFromTypeString(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
GetTypeInfoOperation - Class in org.apache.hive.service.cli.operation
GetTypeInfoOperation.
GetTypeInfoOperation(HiveSession) - Constructor for class org.apache.hive.service.cli.operation.GetTypeInfoOperation
 
getTypeInfosFromTypeString(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
getTypeMap() - Method in class org.apache.hive.jdbc.HiveConnection
 
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
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
getTypeName() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector
Returns the name of the data type that is inspected by this ObjectInspector.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the type name for this primitive ObjectInspector.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
A String representation of the TypeInfo.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
 
getTypeName() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
getTypeName() - Method in class org.apache.hive.service.cli.TypeDescriptor
 
getTypeNameFromJavaClass(Type) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the type name of the Java class.
getTypeNameFromPrimitiveJava(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the typeName from a Java Primitive Type or Java PrimitiveClass.
getTypeNameFromPrimitiveWritable(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the typeName from a Primitive Writable Class.
getTypeNames() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
getTypeNames() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap.Mapping
 
getTypeQualifiers() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
getTypeQualifiers() - Method in class org.apache.hive.service.cli.TypeDescriptor
 
getTypes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
getTypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.Type types = 4;
getTypes(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.Type types = 4;
getTypes() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the list of types contained in the file.
getTypes() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getTypes() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
getTypesBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.Type types = 4;
getTypesCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.Type types = 4;
getTypesIterator() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
getTypesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.Type types = 4;
getTypesList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.Type types = 4;
getTypesOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesOrBuilder(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.Type types = 4;
getTypesOrBuilder(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.Type types = 4;
getTypesOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
getTypesOrBuilderList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
repeated .orc.proto.Type types = 4;
getTypesOrBuilderList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
repeated .orc.proto.Type types = 4;
getTypesSize() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
getTypesString() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
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
 
getTypeString() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
getTypeStringFromAST(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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
 
getUDTs(String, String, String, int[]) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getUgi() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getUGI() - Static method in class org.apache.hadoop.hive.shims.Utils
 
getUgi(String) - Static method in class org.apache.hive.hcatalog.templeton.UgiFactory
 
getUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getUnderscoreInt() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
getUndo() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
getUndo() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
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.
getUnicodeStream(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getUnicodeStream(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getUnionAllAST(ASTNode, ASTNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ASTConverter
 
getUnionEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getUnionField1() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getUnionField2() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getUnionField3() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getUnionMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
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
 
getUnionStructObjectInspector(List<StructObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getUnionTask(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getUnionTypeInfo(List<TypeInfo>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getUniqueKey(long, String, String, Map<String, String>) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Used to generate a unique key for a combination of given event id, dbname, tablename and partition keyvalues.
getUniqueKeys(Project, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdUniqueKeys
 
getUnixScriptNameFor(String) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
getUnknownFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
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
 
getUnscaled() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
getUnscaledValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns unscaled value of this Decimal128.
getUnsupportedFeature() - Method in exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
getUpdate(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares UPDATE statement issued when updating existing statistics
getUpdateColumnAccessInfo() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getUpdateCount() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getUpdateCount() - Method in class org.apache.hive.jdbc.HiveStatement
 
getUpdateLocations() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMDatabaseURIRetVal
 
getUpdateLocations() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMStorageDescriptorTblURIRetVal
 
getUpdateLocations() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdatePropURIRetVal
 
getUpdateLocations() - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateSerdeURIRetVal
 
getUpgradeScripts(String) - Method in class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
Get the list of sql scripts required to upgrade from the give version to current
getUri() - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getUri() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
getUri() - Method in class org.apache.hadoop.hive.metastore.model.MResourceUri
 
getURI(String) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
getURL(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.mr.JobTrackerURLResolver
 
getUrl() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the subversion URL for the root Hive directory.
getURL(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getURL(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getURL(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getURL(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getURL() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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.conf.HiveConf
 
getUser() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
getUser() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
getUser() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
getUser() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
getUser() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
getUser() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getUser() - Static method in class org.apache.hive.common.util.HiveVersionInfo
The user that compiled Hive.
getUser() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
The user who started this job.
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
getUserArgs() - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
getUserDefinedTypeEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
getUserFromAuthenticator() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getUserFromToken(String) - Method in class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
 
getUserFromToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getUserFromToken(String) - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
getUserGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getUserIpAddress() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
Get user's ip address.
getUserIpAddress() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getUserIpAddress() - Static method in class org.apache.hive.service.auth.TSetIpAddressProcessor
 
getUserMetadata() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
getUserName() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
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
 
getUserName() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getUserName() - Static method in class org.apache.hive.service.auth.TSetIpAddressProcessor
 
getUsername() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getUserName() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
getUsername() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getUserName() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
getUserName() - Static method in class org.apache.hive.service.cli.session.SessionManager
 
getUsername() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
getUserNameFromCookieToken(String) - Static method in class org.apache.hive.service.auth.HttpAuthUtils
Parses a cookie token to retrieve client user name.
getUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getUserPrivilegeSet(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getUserPrivilegeSet(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getUserPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getUTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getUtf8Value(ConstantObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
getUtils() - Static method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
getUtils() - Static method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
getV() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getV0() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
getV0() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getV1() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
getV1() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getV2() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
getV2() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getV3() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
getV3() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
getValidatedPartSpec(Table, ASTNode, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
getValidatedPrincipal(HivePrincipal) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
Validate the principal type, and convert role name to lower case
getValidatedPrincipals(List<HivePrincipal>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
Calls getValidatedPrincipal on each principal in list and updates the list
getValidator() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
getValidAuthMethod(String) - Static method in enum org.apache.hive.service.auth.AuthenticationProviderFactory.AuthMethods
 
getValidConfVar(HiveConf.ConfVars, HiveConf) - Static method in class org.apache.hive.beeline.HiveSchemaHelper
 
getValidTxns() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getValidTxns(long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getValidTxns() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a structure that details valid transactions.
getValidTxns(long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a structure that details valid transactions.
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.accumulo.AccumuloHiveRow.ColumnTuple
 
getValue(Text, Text) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
getValue() - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
getValue() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Get the typed bytes as a Java object.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.CompactionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.EventRequestType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.FunctionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.LockLevel
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.LockState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.LockType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.PartitionEventType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.ResourceType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.TxnState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatistic
 
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.gen.DateColAddIntervalDayTimeScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.StringGroupColConcatStringScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringScalarConcatStringGroupCol
 
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.io.orc.OrcProto.UserMetadataItem.Builder
optional bytes value = 2;
getValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
optional bytes value = 2;
getValue() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItemOrBuilder
optional bytes value = 2;
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getValue() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.MyEnum
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.service.JobTrackerState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
getValue() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
getValue() - Method in enum org.apache.hive.service.cli.thrift.TFetchOrientation
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hive.service.cli.thrift.TGetInfoType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
getValue() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
getValue() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
getValue() - Method in enum org.apache.hive.service.cli.thrift.TOperationState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hive.service.cli.thrift.TOperationType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hive.service.cli.thrift.TProtocolVersion
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hive.service.cli.thrift.TStatusCode
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
getValue() - Method in enum org.apache.hive.service.cli.thrift.TTypeId
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue(HiveConf, String) - Static method in class org.apache.hive.spark.client.rpc.RpcConfiguration
Utility method for a given RpcConfiguration key, to convert value to millisecond if it is a time value, and return as string in either case.
getValue() - Method in class org.apache.hive.spark.counter.SparkCounter
 
getValue(String, String) - Method in class org.apache.hive.spark.counter.SparkCounters
 
getValueBuffer() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
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
 
getValueColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap.Mapping
 
getValueContext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
getValueDescriptor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
getValueDescriptor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
getValueDescriptor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
getValueDescriptor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
getValueEncoding() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
getValueFactories() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
getValueFilteredTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValueIndex() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getValueIndex(byte) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValueIndices() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
getValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
getValueObjectInspectors(byte, List<ObjectInspector>[]) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
getValueObjectInspectors(byte, List<ObjectInspector>[]) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getValueObjectInspectors(byte, List<ObjectInspector>[]) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getValueResult(byte[], int, int, BytesBytesMultiHashMap.Result) - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Finds a key.
getValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValues() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getValues() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getValues() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getValues() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getValues() - Method in class org.apache.hive.hcatalog.api.HCatPartition
Gets the values.
getValues() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
getValues() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
getValueSerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
getValuesIterator() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
getValuesSerializeInfos() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
getValuesSize() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
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
 
getValueType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getValueTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
getVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getVar(Configuration, HiveConf.ConfVars, String) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getVarchar(String, HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
getVarcharTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getVarcharTypeInfo(int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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
 
getVColsMap(List<VirtualColumn>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
getVCSObjectInspector(List<VirtualColumn>) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getVectorColumnNameMap() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getVectorColumnSimpleName(VectorExpressionDescriptor.ArgumentType) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
getVectorColumnSimpleName(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
getVectorColumnTypeMap() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getVectorDesc() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getVectorDesc() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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.PTFTopNHash
 
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.PTFTopNHash
 
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.
getVectorizedKeyHashCode(int) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
getVectorizedKeyHashCode(int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
After vectorized batch is processed, can return hashCode of a key.
getVectorizedKeyToForward(int) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
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.AbstractOperatorDesc
 
getVectorModeOn() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getVectorModeOn() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getVectorOperator(Class<? extends Operator<?>>, T, VectorizationContext) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
getVectorOperator(T, VectorizationContext) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
getVectorScratchColumnTypeMap() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
getVersion() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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 class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
getVersion(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
getVersion(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
repeated uint32 version = 4 [packed = true];
getVersion(int) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
repeated uint32 version = 4 [packed = true];
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
 
getVersion() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveV1Authorizer
 
getVersion() - Static method in class org.apache.hive.common.util.HiveVersionInfo
Get the Hive version.
getVersion() - Method in class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
getVersion() - Method in class org.apache.hive.hcatalog.messaging.MessageFactory
Getter for version-string, corresponding to all constructed messages.
getVersion(String) - Method in class org.apache.hive.hcatalog.templeton.VersionDelegator
 
getVersionColumns(String, String, String) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
getVersionComment() - Method in class org.apache.hadoop.hive.metastore.model.MVersionTable
 
getVersionCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
getVersionCount() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
repeated uint32 version = 4 [packed = true];
getVersionCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
repeated uint32 version = 4 [packed = true];
getVersionList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
getVersionList() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
repeated uint32 version = 4 [packed = true];
getVersionList() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
repeated uint32 version = 4 [packed = true];
GetVersionPref - Class in org.apache.hadoop.hive.ant
Implementation of the ant task .
GetVersionPref() - Constructor for class org.apache.hadoop.hive.ant.GetVersionPref
 
getVertexName() - Method in class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
getVertexType() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
getVertexType(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
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.metastore.api.Table
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
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.metastore.api.Table
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getVirtualCols(List<? extends RexNode>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
Get list of virtual columns from the given list of projections.
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
 
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getVirtualColumns() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getVisibility() - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
getVisitedJoinOp() - Static method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinProcFactory
 
getVisitedReduceSinks() - Method in class org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext
 
getWarnings() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
getWarnings() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
getWarnings() - Method in class org.apache.hive.jdbc.HiveConnection
 
getWarnings() - Method in class org.apache.hive.jdbc.HiveStatement
 
getWdwProcessingOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
getWebhcatConfDir() - Static method in class org.apache.hive.hcatalog.templeton.AppConfig
 
getWebHCatShim(Configuration, UserGroupInformation) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getWebHCatShim(Configuration, UserGroupInformation) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getWebHCatShim(Configuration, UserGroupInformation) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Provides a Hadoop JobTracker shim.
getWFnEval() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getWFnEvalExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getWh() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getWhereClauseSubQueryPredicate() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getWhrForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWhRoot() - Method in class org.apache.hadoop.hive.metastore.Warehouse
Resolve the configured warehouse root dir with respect to the configuration This involves opening the FileSystem corresponding to the warehouse root dir (but that should be ok given that this is only called during DDL statements for non-external tables).
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
 
getWindowFrameExplain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getWindowFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getWindowFunctionInfo(String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
getWindowFunctions() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
getWindowFunctionSpec() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
When evaluating an aggregates over a fixed Window, the naive way to compute results is to compute the aggregate for each row.
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag.GenericUDAFLagEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead.GenericUDAFLeadEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
getWindowingEvaluator(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
getWindowingExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWindowingFunctionHelpers() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
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
 
getWorkerid() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
getWorkMap() - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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
 
getWritable() - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
Convert this LazyHCatRecord to a DefaultHCatRecord.
getWritableConstantValue() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ConstantObjectInspector
 
getWritableConstantValue(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantBinaryObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantBooleanObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantByteObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantDateObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantDoubleObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantFloatObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveCharObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveDecimalObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveVarcharObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantIntObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantLongObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantShortObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantStringObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantTimestampObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantBinaryObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantBooleanObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantByteObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantDateObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantDoubleObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantFloatObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveCharObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveDecimalObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveIntervalDayTimeObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveIntervalYearMonthObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveVarcharObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantIntObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantLongObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantShortObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantStringObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantTimestampObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableVoidObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantListObjectInspector
 
getWritableConstantValue() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantMapObjectInspector
 
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
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalDayTime
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalYearMonth
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyTimestamp
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
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
 
getWritableObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Ensures that an ObjectInspector is Writable.
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
getWriteHelper() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
getWritePoint() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
getWriter() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterContext
 
getWriteReqPriv() - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider.DropPrivilegeExtractor
 
getWriterTimezone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
getWriterTimezone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
optional string writerTimezone = 3;
getWriterTimezone() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
optional string writerTimezone = 3;
getWriterTimezoneBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
getWriterTimezoneBytes() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
optional string writerTimezone = 3;
getWriterTimezoneBytes() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
optional string writerTimezone = 3;
getWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint32 writerVersion = 6;
getWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint32 writerVersion = 6;
getWriterVersion() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint32 writerVersion = 6;
getWriterVersion() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the version of the writer of this file.
getWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
getWriteType() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Determine which type of write this is.
getWriteType() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getWriteType() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getWriteType() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getXpathOrFuncExprNodeDesc(ASTNode, boolean, ArrayList<ExprNodeDesc>, TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getYears() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
getZeroCopyReader(FSDataInputStream, HadoopShims.ByteBufferPoolShim) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
getZeroCopyReader(FSDataInputStream, HadoopShims.ByteBufferPoolShim) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
getZeroCopyReader(FSDataInputStream, HadoopShims.ByteBufferPoolShim) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Provides an HDFS ZeroCopyReader shim.
getZooKeeperEnsemble() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
getZooKeepers() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
gFromClauseParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
gHiveParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
gHiveParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
gHiveParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
gIdentifiersParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
go(String) - Method in class org.apache.hive.beeline.Commands
 
gParent - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
gParent - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
gParent - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
grant_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
grant_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
grant_revoke_privileges(GrantRevokePrivilegeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_revoke_privileges(GrantRevokePrivilegeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_revoke_privileges(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_revoke_privileges(GrantRevokePrivilegeRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_revoke_privileges(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_revoke_role(GrantRevokeRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_revoke_role(GrantRevokeRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_revoke_role(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_revoke_role(GrantRevokeRoleRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_revoke_role(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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
 
grantOptionFor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.metastore.ObjectStore
 
grantPrivileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
grantPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantPrivileges() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveV1Authorizer
 
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
GrantRevokePrivilegeRequest - Class in org.apache.hadoop.hive.metastore.api
 
GrantRevokePrivilegeRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
GrantRevokePrivilegeRequest(GrantRevokeType, PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
GrantRevokePrivilegeRequest(GrantRevokePrivilegeRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
Performs a deep copy on other.
GrantRevokePrivilegeRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GrantRevokePrivilegeResponse - Class in org.apache.hadoop.hive.metastore.api
 
GrantRevokePrivilegeResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
GrantRevokePrivilegeResponse(GrantRevokePrivilegeResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
Performs a deep copy on other.
GrantRevokePrivilegeResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
GrantRevokeRoleRequest - Class in org.apache.hadoop.hive.metastore.api
 
GrantRevokeRoleRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
GrantRevokeRoleRequest(GrantRevokeType, String, String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
GrantRevokeRoleRequest(GrantRevokeRoleRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Performs a deep copy on other.
GrantRevokeRoleRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GrantRevokeRoleResponse - Class in org.apache.hadoop.hive.metastore.api
 
GrantRevokeRoleResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
GrantRevokeRoleResponse(GrantRevokeRoleResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
Performs a deep copy on other.
GrantRevokeRoleResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GrantRevokeType - Enum in org.apache.hadoop.hive.metastore.api
 
grantRole(Role, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
grantRole(Role, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
grantRole(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveV1Authorizer
 
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
Graph - Class in org.apache.hadoop.hive.ql.plan.api
 
Graph() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
 
Graph(NodeType, List<String>, List<Adjacency>) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
 
Graph(Graph) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
Performs a deep copy on other.
Graph._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GraphWalker - Interface in org.apache.hadoop.hive.ql.lib
Interface for operator graph walker.
greaterThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
GreaterThan - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to greaterThan over PrimitiveComparison instance.
GreaterThan() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThan
 
GreaterThan(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThan
 
greaterThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
greaterThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
greaterThan(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
greaterThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
greaterThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
GreaterThanOrEqual - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to greaterThanOrEqual over PrimitiveComparison instance.
GreaterThanOrEqual() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThanOrEqual
 
GreaterThanOrEqual(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThanOrEqual
 
greaterThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
greaterThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
greaterThanOrEqual(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
greaterThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
GROOVY - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
group(Configuration, Multimap<Integer, InputSplit>, int, float) - Method in class org.apache.hadoop.hive.ql.exec.tez.SplitGrouper
group splits for each bucket separately - while evenly filling all the available slots with tasks
group - Variable in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
groupByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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>, 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, 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.
groupByDescModeToUDAFMode(GroupByDesc.Mode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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
 
GroupByShuffler - Class in org.apache.hadoop.hive.ql.exec.spark
 
GroupByShuffler() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.GroupByShuffler
 
groupingExpressionSingle() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupingExpressionSingle() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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
 
groupingSetExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupingSetExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
groupingSetExpressionMultiple() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupingSetExpressionMultiple() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
groupKeyObject - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
groupNames - Variable in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
GroupPermissionsDesc - Class in org.apache.hive.hcatalog.templeton
The base create permissions for ddl objects.
GroupPermissionsDesc() - Constructor for class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
gSelectClauseParser - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 

H

Hadoop20SShims - Class in org.apache.hadoop.hive.shims
Implemention of shims against Hadoop 0.20 with Security.
Hadoop20SShims() - Constructor for class org.apache.hadoop.hive.shims.Hadoop20SShims
 
Hadoop20SShims.Hadoop20SFileStatus - Class in org.apache.hadoop.hive.shims
 
Hadoop20SShims.Hadoop20SFileStatus(FileStatus) - Constructor for class org.apache.hadoop.hive.shims.Hadoop20SShims.Hadoop20SFileStatus
 
Hadoop20SShims.KerberosNameShim - Class in org.apache.hadoop.hive.shims
Shim for KerberosName
Hadoop20SShims.KerberosNameShim(String) - Constructor for class org.apache.hadoop.hive.shims.Hadoop20SShims.KerberosNameShim
 
Hadoop20SShims.MiniDFSShim - Class in org.apache.hadoop.hive.shims
MiniDFSShim.
Hadoop20SShims.MiniDFSShim(MiniDFSCluster) - Constructor for class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniDFSShim
 
Hadoop20SShims.MiniMrShim - Class in org.apache.hadoop.hive.shims
Shim for MiniMrCluster
Hadoop20SShims.MiniMrShim(Configuration, int, String, int) - Constructor for class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniMrShim
 
HADOOP20SVERSIONNAME - Static variable in class org.apache.hadoop.hive.shims.ShimLoader
 
Hadoop23Shims - Class in org.apache.hadoop.hive.shims
Implemention of shims against Hadoop 0.23.0.
Hadoop23Shims() - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims
 
Hadoop23Shims.Hadoop23FileStatus - Class in org.apache.hadoop.hive.shims
 
Hadoop23Shims.Hadoop23FileStatus(FileStatus, AclStatus) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.Hadoop23FileStatus
 
Hadoop23Shims.HdfsEncryptionShim - Class in org.apache.hadoop.hive.shims
 
Hadoop23Shims.HdfsEncryptionShim(URI, Configuration) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
Hadoop23Shims.KerberosNameShim - Class in org.apache.hadoop.hive.shims
Shim for KerberosName
Hadoop23Shims.KerberosNameShim(String) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.KerberosNameShim
 
Hadoop23Shims.MiniDFSShim - Class in org.apache.hadoop.hive.shims
MiniDFSShim.
Hadoop23Shims.MiniDFSShim(MiniDFSCluster) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniDFSShim
 
Hadoop23Shims.MiniMrShim - Class in org.apache.hadoop.hive.shims
Shim for MiniMrCluster
Hadoop23Shims.MiniMrShim() - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniMrShim
 
Hadoop23Shims.MiniMrShim(Configuration, int, String, int) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniMrShim
 
Hadoop23Shims.MiniSparkShim - Class in org.apache.hadoop.hive.shims
Shim for MiniSparkOnYARNCluster
Hadoop23Shims.MiniSparkShim(Configuration, int, String, int) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniSparkShim
 
Hadoop23Shims.MiniTezShim - Class in org.apache.hadoop.hive.shims
Shim for MiniTezCluster
Hadoop23Shims.MiniTezShim(Configuration, int, String, int) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniTezShim
 
Hadoop23Shims.StoragePolicyShim - Class in org.apache.hadoop.hive.shims
 
Hadoop23Shims.StoragePolicyShim(DistributedFileSystem) - Constructor for class org.apache.hadoop.hive.shims.Hadoop23Shims.StoragePolicyShim
 
HADOOP23VERSIONNAME - Static variable in class org.apache.hadoop.hive.shims.ShimLoader
 
HADOOP_CHILD_JAVA_OPTS - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_CLASSPATH - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
HADOOP_CLASSPATH_EXTRAS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
A comma-separated list of files to be added to HADOOP_CLASSPATH in LaunchMapper.
HADOOP_CONF_DIR - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_CONF_FILENAMES - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_END_INTERVAL_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_END_RETRY_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_END_URL_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
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.
HADOOP_MAP_MEMORY_MB - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_MR_AM_JAVA_OPTS - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_MR_AM_MEMORY_MB - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_PREFIX_VARS - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_QUEUE_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HADOOP_SPECULATIVE_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
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
 
hadoopFsFilename(String, Configuration, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
hadoopFsIsMissing(FileSystem, Path) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
hadoopFsListAsArray(String, Configuration, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
hadoopFsListAsString(String, Configuration, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
hadoopFsListChildren(String, Configuration, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Returns all files (non-recursive) in dirName
hadoopFsPath(String, Configuration, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
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
 
hadoopQueueName() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
HadoopShims - Interface in org.apache.hadoop.hive.shims
In order to be compatible with multiple versions of Hadoop, all parts of the Hadoop interface that are not cross-version compatible are encapsulated in an implementation of this class.
HadoopShims.ByteBufferPoolShim - Interface in org.apache.hadoop.hive.shims
a hadoop.io ByteBufferPool shim.
HadoopShims.CombineFileInputFormatShim<K,V> - Interface in org.apache.hadoop.hive.shims
CombineFileInputFormatShim.
HadoopShims.DirectCompressionType - Enum in org.apache.hadoop.hive.shims
 
HadoopShims.DirectDecompressorShim - Interface in org.apache.hadoop.hive.shims
 
HadoopShims.HCatHadoopShims - Interface in org.apache.hadoop.hive.shims
 
HadoopShims.HCatHadoopShims.PropertyName - Enum in org.apache.hadoop.hive.shims
 
HadoopShims.HdfsEncryptionShim - Interface in org.apache.hadoop.hive.shims
This interface encapsulates methods used to get encryption information from HDFS paths.
HadoopShims.HdfsFileStatus - Interface in org.apache.hadoop.hive.shims
Includes the vanilla FileStatus, and AclStatus if it applies to this version of hadoop.
HadoopShims.JobTrackerState - Enum in org.apache.hadoop.hive.shims
 
HadoopShims.KerberosNameShim - Interface in org.apache.hadoop.hive.shims
Shim for KerberosName
HadoopShims.MiniDFSShim - Interface in org.apache.hadoop.hive.shims
Shim around the functions in MiniDFSCluster that Hive uses.
HadoopShims.MiniMrShim - Interface in org.apache.hadoop.hive.shims
Shim for MiniMrCluster
HadoopShims.NoopHdfsEncryptionShim - Class in org.apache.hadoop.hive.shims
This is a dummy class used when the hadoop version does not support hdfs encryption.
HadoopShims.NoopHdfsEncryptionShim() - Constructor for class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
HadoopShims.StoragePolicyShim - Interface in org.apache.hadoop.hive.shims
 
HadoopShims.StoragePolicyValue - Enum in org.apache.hadoop.hive.shims
Create a shim for DFS storage policy.
HadoopShims.WebHCatJTShim - Interface in org.apache.hadoop.hive.shims
 
HadoopShims.ZeroCopyReaderShim - Interface in org.apache.hadoop.hive.shims
 
HadoopShimsSecure - Class in org.apache.hadoop.hive.shims
Base implemention for shims against secure Hadoop 0.20.3/0.23.
HadoopShimsSecure() - Constructor for class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
HadoopShimsSecure.CombineFileInputFormatShim<K,V> - Class in org.apache.hadoop.hive.shims
 
HadoopShimsSecure.CombineFileInputFormatShim() - Constructor for class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileInputFormatShim
 
HadoopShimsSecure.CombineFileRecordReader<K,V> - Class in org.apache.hadoop.hive.shims
 
HadoopShimsSecure.CombineFileRecordReader(JobConf, CombineFileSplit, Reporter, Class<RecordReader<K, V>>) - Constructor for class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
A generic RecordReader that can hand out different recordReaders for each chunk in the CombineFileSplit.
HadoopShimsSecure.InputSplitShim - Class in org.apache.hadoop.hive.shims
 
HadoopShimsSecure.InputSplitShim() - Constructor for class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
HadoopShimsSecure.InputSplitShim(JobConf, Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
HadoopThriftAuthBridge - Class in org.apache.hadoop.hive.thrift
Functions that bridge Thrift's SASL transports to Hadoop's SASL callback handlers and authentication classes.
HadoopThriftAuthBridge() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
HadoopThriftAuthBridge.Client - Class in org.apache.hadoop.hive.thrift
 
HadoopThriftAuthBridge.Client() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Client
 
HadoopThriftAuthBridge.Server - Class in org.apache.hadoop.hive.thrift
 
HadoopThriftAuthBridge.Server() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
HadoopThriftAuthBridge.Server(String, String) - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
Create a server with a kerberos keytab/principal.
HadoopThriftAuthBridge.Server.ServerMode - Enum in org.apache.hadoop.hive.thrift
 
HadoopThriftAuthBridge.Server.TUGIAssumingProcessor - Class in org.apache.hadoop.hive.thrift
Processor that pulls the SaslServer object out of the transport, and assumes the remote user's UGI before calling through to the original processor.
HadoopThriftAuthBridge23 - Class in org.apache.hadoop.hive.thrift
Functions that bridge Thrift's SASL transports to Hadoop's SASL callback handlers and authentication classes.
HadoopThriftAuthBridge23() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge23
 
hadoopUserEnv(String, String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Set the environment variables to specify the hadoop user.
hadoopVersion() - Method in class org.apache.hive.hcatalog.templeton.Server
Get version of hadoop software being run by this WebHCat server
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.
handle(Signal) - Method in class org.apache.hive.beeline.SunSignalHandler
 
handle(Callback[]) - Method in class org.apache.hive.service.auth.PlainSaslHelper.PlainCallbackHandler
 
Handle - Class in org.apache.hive.service.cli
 
Handle() - Constructor for class org.apache.hive.service.cli.Handle
 
Handle(HandleIdentifier) - Constructor for class org.apache.hive.service.cli.Handle
 
Handle(THandleIdentifier) - Constructor for class org.apache.hive.service.cli.Handle
 
handleDateResult(Date) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
handleDateResult(Date) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
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
 
handleFilterUnionChildren(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
If the input filter operator has direct child(ren) which are union operator, and the filter's column is not the same as union's create select operator between them.
HandleIdentifier - Class in org.apache.hive.service.cli
HandleIdentifier.
HandleIdentifier() - Constructor for class org.apache.hive.service.cli.HandleIdentifier
 
HandleIdentifier(UUID, UUID) - Constructor for class org.apache.hive.service.cli.HandleIdentifier
 
HandleIdentifier(THandleIdentifier) - Constructor for class org.apache.hive.service.cli.HandleIdentifier
 
handleInputInitializerEvent(List<InputInitializerEvent>) - Method in class org.apache.hadoop.hive.ql.exec.tez.HiveSplitGenerator
 
handleIntervalDayTimeResult(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
handleIntervalDayTimeResult(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
handleIntervalYearMonthResult(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
handleIntervalYearMonthResult(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
handlePredicates(Node, ExprWalkerInfo, OpWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinerPPD
 
handleRecordReaderCreationException(Exception) - Method in interface org.apache.hadoop.hive.io.HiveIOExceptionHandler
process exceptions raised when creating a record reader.
handleRecordReaderCreationException(Exception) - Method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
 
handleRecordReaderCreationException(Exception, JobConf) - Static method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerUtil
Handle exception thrown when creating record reader.
handleRecordReaderNextException(Exception) - Method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
This is to handle exception when doing next operations.
handleRecordReaderNextException(Exception, JobConf) - Static method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerUtil
Handle exception thrown when calling record reader's next.
handleRecorReaderNextException(Exception, HiveIOExceptionNextHandleResult) - Method in interface org.apache.hadoop.hive.io.HiveIOExceptionHandler
process exceptions thrown when calling rr's next
handleSkew(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
handleTimestampResult(Timestamp) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
handleTimestampResult(Timestamp) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
harFile(Path) - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
HarOutputCommitterPostProcessor - Class in org.apache.hive.hcatalog.har
 
HarOutputCommitterPostProcessor() - Constructor for class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
hasAint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
hasAllFieldsSettable(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
hasAllFieldsSettable(ObjectInspector, Map<ObjectInspector, Boolean>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
hasAnyCandidates() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
hasAnyFiltered(short) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
hasAnyNullObject(List, StructObjectInspector, boolean[]) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
return false though element is null if nullsafe flag is true for that
hasAnyNullObject(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
True if Object passed is representing null object.
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.MapJoinKeyObject
 
hasAnyNulls(int, boolean[]) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
Checks whether the current key has any nulls.
hasAString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
hasBase() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
hasBase() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
hasBinaryStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
hasBinaryStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
hasBinaryStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
hasBucketStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
hasBucketStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.BucketStatistics bucketStatistics = 5;
hasBucketStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
hasClusterBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasColumn() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint32 column = 2;
hasColumn() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional uint32 column = 2;
hasColumn() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional uint32 column = 2;
hasColumnEncoding(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
Determines if a custom encoding was specified for the give column.
hasColumnExpr(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Whether the expression contains a column node or not.
hasCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional .orc.proto.CompressionKind compression = 2;
hasCompression() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional .orc.proto.CompressionKind compression = 2;
hasCompression() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional .orc.proto.CompressionKind compression = 2;
hasCompressionBlockSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 compressionBlockSize = 3;
hasCompressionBlockSize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 compressionBlockSize = 3;
hasCompressionBlockSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 compressionBlockSize = 3;
hasContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 contentLength = 2;
hasContentLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 contentLength = 2;
hasContentLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 contentLength = 2;
hasContiguousNext() - Method in class org.apache.hadoop.hive.common.DiskRangeList
 
hasData() - Method in class org.apache.hadoop.hive.common.DiskRange
 
hasDataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 dataLength = 3;
hasDataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 dataLength = 3;
hasDataLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 dataLength = 3;
hasDateStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
hasDateStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DateStatistics dateStatistics = 7;
hasDateStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DateStatistics dateStatistics = 7;
hasDecimal() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
hasDecimalStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
hasDecimalStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
hasDecimalStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
hasDictionarySize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional uint32 dictionarySize = 2;
hasDictionarySize() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
optional uint32 dictionarySize = 2;
hasDictionarySize() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncodingOrBuilder
optional uint32 dictionarySize = 2;
hasDictionarySupport() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
hasDictionarySupport() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
hasDistributeBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasDoubleStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
hasDoubleStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
hasDoubleStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
hasDropPrivilege() - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider.DropPrivilegeExtractor
 
hasDynamicPartitions - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
hasDynamicPartitions() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
hasDynamicPartitions() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
hasDynamicPartitions() - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
hasError() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
hasErrors() - Method in class org.apache.hive.beeline.util.QFileClient
 
hasExpectedResults() - Method in class org.apache.hive.beeline.util.QFileClient
Does the test have a file with expected results to compare the log against.
hasExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
hasFamAndQual(Text, Text) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
hasFile - Variable in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
hasFilter(int) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
hasFilterTag() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
hasFilterWithSubQuery() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasFooter() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
hasFooter() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
hasFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 footerLength = 1;
hasFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 footerLength = 1;
hasFooterLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 footerLength = 1;
hasFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 footerLength = 4;
hasFooterLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 footerLength = 4;
hasFooterLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 footerLength = 4;
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
 
hasGroupingSet(ReduceSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
hash128(byte[]) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 128-bit variant.
hash128(byte[], int, int) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 128-bit variant.
hash32(byte[]) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 32-bit variant.
hash32(byte[], int, int) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 32-bit variant.
hash64(byte[]) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 64-bit variant.
hash64(byte[], int) - Static method in class org.apache.hive.common.util.Murmur3
 
hash64(byte[], int, int) - Static method in class org.apache.hive.common.util.Murmur3
Murmur3 64-bit variant.
hasHasNull() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional bool hasNull = 10;
hasHasNull() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional bool hasNull = 10;
hasHasNull() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional bool hasNull = 10;
hashBytes(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
hashCode() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
hashCode() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
hashCode() - Method in class org.apache.hadoop.hive.common.DiskRange
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns the hash code for this Decimal128.
hashCode() - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
hashCode() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
hashCode() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
HWIAuth is used in Map(s) the hashCode method is required.
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
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.lockmgr.HiveLockObject
 
hashCode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
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.metadata.VirtualColumn
 
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.api.Adjacency
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
hashCode() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
hashCode() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryObject
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
hashCode(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
Generate the hashCode for this TypeInfo.
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
Generate the hashCode for this TypeInfo.
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
Generate the hashCode for this TypeInfo.
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
Generate the hashCode for this TypeInfo.
hashCode(long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
hashCode(long, int, WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
hashCode(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
hashCode() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
hashCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
hashCode() - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
hashCode() - Method in class org.apache.hive.hcatalog.data.Pair
 
hashCode() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
hashCode() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
hashCode() - Method in class org.apache.hive.hcatalog.mapreduce.HCatTableInfo
 
hashCode() - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
hashCode() - Method in class org.apache.hive.service.cli.Handle
 
hashCode() - Method in class org.apache.hive.service.cli.HandleIdentifier
 
hashCode() - Method in class org.apache.hive.service.cli.OperationHandle
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TRow
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
hashCode() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
hasHeaderLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 headerLength = 1;
hasHeaderLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 headerLength = 1;
hasHeaderLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 headerLength = 1;
hashKey(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashUtil
 
hashKey(int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastIntHashUtil
 
hashKey(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashUtil
 
hashMap(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
hashMapEntry() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
hashMapResults - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
hashMapResults - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
hashMapRowGetters - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
HashMapWrapper - Class in org.apache.hadoop.hive.ql.exec.persistence
Simple wrapper for persistent Hashmap implementing only the put/get/remove/clear interface.
HashMapWrapper(Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashMapWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashMapWrapper(Configuration, long) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
hashMultiSetResults - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
hashSet(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
hashSetResults - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
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
 
hashTableImplementationType() - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
hashTableKeyType() - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
hashTableKind() - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
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.spark
HashTableLoader for Spark to load the hashtable for MapJoins.
HashTableLoader() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.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
 
hasIndexLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 indexLength = 2;
hasIndexLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 indexLength = 2;
hasIndexLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 indexLength = 2;
hasIntStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
hasIntStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.IntegerStatistics intStatistics = 2;
hasIntStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.IntegerStatistics intStatistics = 2;
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
 
hasKey(String) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
Check if we're tracking a certain named key/metric
hasKey(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
optional .orc.proto.ColumnEncoding.Kind kind = 1;
hasKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncodingOrBuilder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional .orc.proto.Stream.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional .orc.proto.Stream.Kind kind = 1;
hasKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional .orc.proto.Stream.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional .orc.proto.Type.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional .orc.proto.Type.Kind kind = 1;
hasKind() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional .orc.proto.Type.Kind kind = 1;
hasLateralViews() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint64 length = 3;
hasLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
optional uint64 length = 3;
hasLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StreamOrBuilder
optional uint64 length = 3;
hasMagic() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
hasMagic() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional string magic = 8000;
hasMagic() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional string magic = 8000;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
optional sint32 maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatisticsOrBuilder
optional sint32 maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 maximum = 2;
hasMaximum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
optional sint64 maximum = 2;
hasMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatisticsOrBuilder
optional sint64 maximum = 2;
hasMaximumLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 maximumLength = 4;
hasMaximumLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 maximumLength = 4;
hasMaximumLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 maximumLength = 4;
hasMetadataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 metadataLength = 5;
hasMetadataLength() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint64 metadataLength = 5;
hasMetadataLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint64 metadataLength = 5;
hasMetadataValue(String) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Did the user set the given metadata value.
hasMetadataValue(String) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
hasMetastoreBasedSchema(HiveConf, StorageDescriptor) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
 
hasMetastoreBasedSchema(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
 
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
optional sint32 minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatisticsOrBuilder
optional sint32 minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional string minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional string minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 minimum = 1;
hasMinimum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
optional sint64 minimum = 1;
hasMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatisticsOrBuilder
optional sint64 minimum = 1;
hasMoreLogs() - Method in class org.apache.hive.jdbc.HiveStatement
Check whether query execution might be producing more logs to be fetched.
hasMultiDestQuery() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasMyint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
hasMyString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
hasName() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItemOrBuilder
optional string name = 1;
hasNext() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
hasNext() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
hasNext() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
hasNext() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
hasNext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
hasNext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
hasNext() - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
hasNext() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList.ResultIterator
 
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
 
hasNext() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingIterator
 
hasNext() - Method in class org.apache.hive.beeline.IncrementalRows
 
hasNext() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec.HCatPartitionIterator
 
hasNext() - Method in class org.apache.hive.hcatalog.api.repl.HCatReplicationTaskIterator
 
hasNull() - Method in interface org.apache.hadoop.hive.ql.io.orc.ColumnStatistics
Returns true if there are nulls in the scope of column statistics.
HASNULL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
hasNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 numberOfRows = 6;
hasNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint64 numberOfRows = 6;
hasNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint64 numberOfRows = 6;
hasNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 numberOfRows = 5;
hasNumberOfRows() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 numberOfRows = 5;
hasNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 numberOfRows = 5;
hasNumberOfValues() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional uint64 numberOfValues = 1;
hasNumberOfValues() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional uint64 numberOfValues = 1;
hasNumberOfValues() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional uint64 numberOfValues = 1;
hasNumHashFunctions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
optional uint32 numHashFunctions = 1;
hasNumHashFunctions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
optional uint32 numHashFunctions = 1;
hasNumHashFunctions() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterOrBuilder
optional uint32 numHashFunctions = 1;
hasOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 offset = 1;
hasOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
optional uint64 offset = 1;
hasOffset() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformationOrBuilder
optional uint64 offset = 1;
hasOrderBy() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
hasOrderBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasOuterOrderBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasParameters(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
hasPrecision() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 precision = 5;
hasPrecision() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 precision = 5;
hasPrecision() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 precision = 5;
hasPTF() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasReachedMaxSize - Variable in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
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
 
hasResources(String[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
hasResultSet - Variable in class org.apache.hive.service.cli.operation.Operation
 
hasResultSet() - Method in class org.apache.hive.service.cli.operation.Operation
 
hasResultSet() - Method in class org.apache.hive.service.cli.OperationHandle
 
hasRowIdMapping() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
hasRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint32 rowIndexStride = 8;
hasRowIndexStride() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
optional uint32 rowIndexStride = 8;
hasRowIndexStride() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.FooterOrBuilder
optional uint32 rowIndexStride = 8;
hasRows() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
hasRows() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
hasScale() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 scale = 6;
hasScale() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
optional uint32 scale = 6;
hasScale() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.TypeOrBuilder
optional uint32 scale = 6;
hasShutdownHook(Runnable) - Static method in class org.apache.hive.common.util.ShutdownHookManager
Indicates if a shutdownHook is registered or not.
hasShutdownHookInternal(Runnable) - Method in class org.apache.hive.common.util.ShutdownHookManager
 
hasSortBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasSpill() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
hasSpill() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
hasSpill() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
hasSpill() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
Checks if the container has spilled any data onto disk.
hasSpill() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
hasStagedAlias() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
hasStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
hasStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
optional .orc.proto.ColumnStatistics statistics = 2;
hasStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntryOrBuilder
optional .orc.proto.ColumnStatistics statistics = 2;
hasStickyBit(FsPermission) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
hasStickyBit(FsPermission) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
hasStickyBit(FsPermission) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Check stick bit in the permission
hasStringStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
hasStringStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.StringStatistics stringStatistics = 4;
hasStringStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.StringStatistics stringStatistics = 4;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
optional sint64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
optional sint64 sum = 1;
hasSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatisticsOrBuilder
optional sint64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
optional string sum = 3;
hasSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatisticsOrBuilder
optional string sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
optional double sum = 3;
hasSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatisticsOrBuilder
optional double sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
optional sint64 sum = 3;
hasSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatisticsOrBuilder
optional sint64 sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional sint64 sum = 3;
hasSum() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
optional sint64 sum = 3;
hasSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatisticsOrBuilder
optional sint64 sum = 3;
hasTableAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
hasTableSample(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
hasTimestampStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
hasTimestampStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
hasTimestampStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatisticsOrBuilder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
hasUnderscoreInt() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
hasUnknownPartitions() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
hasValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
optional bytes value = 2;
hasValue() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItemOrBuilder
optional bytes value = 2;
hasVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
hasVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
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
 
hasWriterTimezone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
hasWriterTimezone() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
optional string writerTimezone = 3;
hasWriterTimezone() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooterOrBuilder
optional string writerTimezone = 3;
hasWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint32 writerVersion = 6;
hasWriterVersion() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
optional uint32 writerVersion = 6;
hasWriterVersion() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScriptOrBuilder
optional uint32 writerVersion = 6;
havingClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
havingClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
havingCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
havingCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
HBASE_AUTOGENERATE_STRUCT - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_COLUMNS_MAPPING - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_COLUMNS_REGEX_MATCHING - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
Determines whether a regex matching should be done on the columns or not.
HBASE_COMPOSITE_KEY_CLASS - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_COMPOSITE_KEY_FACTORY - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_COMPOSITE_KEY_TYPES - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_KEY_COL - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_PUT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_SCAN_BATCH - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_SCAN_CACHE - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_STRUCT_SERIALIZER_CLASS - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_TABLE_DEFAULT_STORAGE_TYPE - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_TABLE_NAME - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_TIMESTAMP_COL - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBASE_WAL_ENABLED - Static variable in class org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat
 
HBaseCompositeKey - Class in org.apache.hadoop.hive.hbase
HBaseCompositeKey extension of LazyStruct.
HBaseCompositeKey(LazySimpleStructObjectInspector) - Constructor for class org.apache.hadoop.hive.hbase.HBaseCompositeKey
 
HBaseKeyFactory - Interface in org.apache.hadoop.hive.hbase
Provides custom implementation of object and object inspector for hbase key.
HBaseLazyObjectFactory - Class in org.apache.hadoop.hive.hbase
 
HBaseLazyObjectFactory() - Constructor for class org.apache.hadoop.hive.hbase.HBaseLazyObjectFactory
 
hbaseParams - Variable in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
hbaseParams - Variable in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
HBaseRowSerializer - Class in org.apache.hadoop.hive.hbase
 
HBaseRowSerializer(HBaseSerDeParameters) - Constructor for class org.apache.hadoop.hive.hbase.HBaseRowSerializer
 
HBaseScanRange - Class in org.apache.hadoop.hive.hbase
 
HBaseScanRange() - Constructor for class org.apache.hadoop.hive.hbase.HBaseScanRange
 
HBaseSerDe - Class in org.apache.hadoop.hive.hbase
HBaseSerDe can be used to serialize object into an HBase table and deserialize objects from an HBase table.
HBaseSerDe() - Constructor for class org.apache.hadoop.hive.hbase.HBaseSerDe
 
HBaseSerDeHelper - Class in org.apache.hadoop.hive.hbase
Helper class for HBaseSerDe
HBaseSerDeHelper() - Constructor for class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
 
HBaseSerDeParameters - Class in org.apache.hadoop.hive.hbase
HBaseSerDeParameters encapsulates SerDeParameters and additional configurations that are specific for HBaseSerDe.
HBaseSplit - Class in org.apache.hadoop.hive.hbase
HBaseSplit augments FileSplit with HBase column mapping.
HBaseSplit() - Constructor for class org.apache.hadoop.hive.hbase.HBaseSplit
For Writable
HBaseSplit(TableSplit, Path) - Constructor for class org.apache.hadoop.hive.hbase.HBaseSplit
 
HBaseSplit(InputSplit, Path) - Constructor for class org.apache.hadoop.hive.hbase.HBaseSplit
TODO: use TableSnapshotRegionSplit HBASE-11555 is fixed.
HBaseStatsAggregator - Class in org.apache.hadoop.hive.hbase
A class that implements the StatsAggregator interface through HBase.
HBaseStatsAggregator() - Constructor for class org.apache.hadoop.hive.hbase.HBaseStatsAggregator
 
HBaseStatsPublisher - Class in org.apache.hadoop.hive.hbase
A class that implements the StatsPublisher interface through HBase.
HBaseStatsPublisher() - Constructor for class org.apache.hadoop.hive.hbase.HBaseStatsPublisher
 
HBaseStatsSetupConstants - Class in org.apache.hadoop.hive.hbase
 
HBaseStatsSetupConstants() - Constructor for class org.apache.hadoop.hive.hbase.HBaseStatsSetupConstants
 
HBaseStatsUtils - Class in org.apache.hadoop.hive.hbase
 
HBaseStatsUtils() - Constructor for class org.apache.hadoop.hive.hbase.HBaseStatsUtils
 
HBaseStorageHandler - Class in org.apache.hadoop.hive.hbase
HBaseStorageHandler provides a HiveStorageHandler implementation for HBase.
HBaseStorageHandler() - Constructor for class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
HBaseStructValue - Class in org.apache.hadoop.hive.hbase.struct
This is an extension of LazyStruct.
HBaseStructValue(LazySimpleStructObjectInspector) - Constructor for class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
 
HBaseTableSnapshotInputFormatUtil - Class in org.apache.hadoop.hive.hbase
A helper class to isolate newer HBase features from users running against older versions of HBase that don't provide those features.
HBaseTableSnapshotInputFormatUtil() - Constructor for class org.apache.hadoop.hive.hbase.HBaseTableSnapshotInputFormatUtil
 
HBaseValueFactory - Interface in org.apache.hadoop.hive.hbase.struct
Provides capability to plugin custom implementations for querying of data stored in HBase.
HCAT_ADD_PARTITION_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_ALTER_PARTITION_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_ALTER_TABLE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_APPEND_LIMIT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
hcat.append.limit allows a hcat user to specify a custom append limit.
HCAT_CLIENT_IMPL_CLASS - Static variable in class org.apache.hive.hcatalog.api.HCatClient
 
HCAT_CREATE_DATABASE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_CREATE_DB_NAME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_CREATE_TABLE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_CREATE_TBL_NAME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DATA_CONVERT_BOOLEAN_TO_INTEGER - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
"hcat.data.convert.boolean.to.integer" (default: false).
HCAT_DATA_CONVERT_BOOLEAN_TO_INTEGER_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DATA_TINY_SMALL_INT_PROMOTION - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
"hcat.data.tiny.small.int.promotion" (default: false).
HCAT_DATA_TINY_SMALL_INT_PROMOTION_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DEFAULT_TOPIC_PREFIX - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DESIRED_PARTITION_NUM_SPLITS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
The desired number of input splits produced for each partition.
HCAT_DROP_DATABASE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DROP_PARTITION_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DROP_TABLE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DYNAMIC_CUSTOM_PATTERN - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_DYNAMIC_PTN_JOBID - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_GROUP - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_HIVE_CLIENT_DISABLE_CACHE - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_HIVE_CLIENT_EXPIRY_TIME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_HOME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants.PigConstants
 
HCAT_HOME_PATH - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
see webhcat-default.xml
HCAT_INPUT_BAD_RECORD_MIN_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_INPUT_BAD_RECORD_MIN_KEY - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
"hcat.input.bad.record.min" (default: 2).
HCAT_INPUT_BAD_RECORD_THRESHOLD_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_INPUT_BAD_RECORD_THRESHOLD_KEY - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
"hcat.input.bad.record.threshold" (default: 9.999999747378752E-5f).
HCAT_INSERT_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_IS_DYNAMIC_MAX_PTN_CHECK_ENABLED - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_BASE - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_HIVE_CONF - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_JOB_INFO - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_OUTPUT_BASE - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_OUTPUT_INFO - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_OUTPUT_SCHEMA - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_KEY_TOKEN_SIGNATURE - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MESSAGE_FORMAT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MESSAGE_VERSION - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_METASTORE_PRINCIPAL - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_METASTORE_URI - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MSG_CLEAN_FREQ - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MSG_EXPIRY_DURATION - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MSGBUS_TOPIC_NAME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MSGBUS_TOPIC_NAMING_POLICY - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_MSGBUS_TOPIC_PREFIX - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HCAT_OUTPUT_ID_HASH - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PARTITION_DONE_EVENT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PERMS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_ARGS_DELIMIT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_ARGS_DELIMIT_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_INNER_FIELD_NAME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_INNER_FIELD_NAME_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_INNER_TUPLE_NAME - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_INNER_TUPLE_NAME_DEFAULT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_LOADER - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_LOADER_ARGS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_LOADER_LOCATION_SET - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_STORAGE_CLASS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_STORER - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_STORER_ARGS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_PIG_STORER_EXTERNAL_LOCATION - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
"hcat.pig.storer.external.location" (default: null) When the property is set in the UDFContext of the org.apache.hive.hcatalog.pig.HCatStorer, HCatStorer writes to the location it specifies instead of the default HCatalog location format.
HCAT_PIG_STORER_LOCATION_SET - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCAT_SERVER_URL - Static variable in class org.apache.hive.hcatalog.messaging.MessageFactory
 
HCAT_SERVICE - Static variable in class org.apache.hive.hcatalog.templeton.SecureProxySupport
 
HCAT_SERVICE_PRINCIPAL - Static variable in class org.apache.hive.hcatalog.messaging.MessageFactory
 
HCAT_TABLE_SCHEMA - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HCatAddPartitionDesc - Class in org.apache.hive.hcatalog.api
The Class HCatAddPartitionDesc helps users in defining partition attributes.
HCatAddPartitionDesc.Builder - Class in org.apache.hive.hcatalog.api
Builder class for constructing an HCatAddPartition instance.
HCatBaseInputFormat - Class in org.apache.hive.hcatalog.mapreduce
 
HCatBaseInputFormat() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
 
HCatBaseOutputFormat - Class in org.apache.hive.hcatalog.mapreduce
 
HCatBaseOutputFormat() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
 
HCatCli - Class in org.apache.hive.hcatalog.cli
 
HCatCli() - Constructor for class org.apache.hive.hcatalog.cli.HCatCli
 
HCatClient - Class in org.apache.hive.hcatalog.api
The abstract class HCatClient containing APIs for HCatalog DDL commands.
HCatClient() - Constructor for class org.apache.hive.hcatalog.api.HCatClient
 
HCatClient.DropDBMode - Enum in org.apache.hive.hcatalog.api
 
HCatClientHMSImpl - Class in org.apache.hive.hcatalog.api
The HCatClientHMSImpl is the Hive Metastore client based implementation of HCatClient.
HCatClientHMSImpl() - Constructor for class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
HCatConstants - Class in org.apache.hive.hcatalog.common
 
HCatContext - Enum in org.apache.hive.hcatalog.common
HCatContext is a singleton that provides global access to configuration data.
HCatCreateDBDesc - Class in org.apache.hive.hcatalog.api
The Class HCatCreateDBDesc for defining database attributes.
HCatCreateDBDesc.Builder - Class in org.apache.hive.hcatalog.api
 
HCatCreateTableDesc - Class in org.apache.hive.hcatalog.api
The Class HCatCreateTableDesc for defining attributes for a new table.
HCatCreateTableDesc.Builder - Class in org.apache.hive.hcatalog.api
 
HCatDatabase - Class in org.apache.hive.hcatalog.api
HCatDatabase is wrapper class around org.apache.hadoop.hive.metastore.api.Database.
HcatDelegator - Class in org.apache.hive.hcatalog.templeton
Run hcat on the local server using the ExecService.
HcatDelegator(AppConfig, ExecService) - Constructor for class org.apache.hive.hcatalog.templeton.HcatDelegator
 
HCatDriver - Class in org.apache.hive.hcatalog.cli
 
HCatDriver() - Constructor for class org.apache.hive.hcatalog.cli.HCatDriver
 
HCatEventMessage - Class in org.apache.hive.hcatalog.messaging
Class representing messages emitted when Metastore operations are done.
HCatEventMessage(HCatEventMessage.EventType) - Constructor for class org.apache.hive.hcatalog.messaging.HCatEventMessage
 
HCatEventMessage.EventType - Enum in org.apache.hive.hcatalog.messaging
Enumeration of all supported types of Metastore operations.
HCatException - Exception in org.apache.hive.hcatalog.common
Class representing exceptions thrown by HCat.
HCatException(ErrorType) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, Throwable) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, String) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, String, Throwable) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HCatException(String) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HCatException(String, Throwable) - Constructor for exception org.apache.hive.hcatalog.common.HCatException
Instantiates a new hcat exception.
HcatException - Exception in org.apache.hive.hcatalog.templeton
Unable to run hcat on the job.
HcatException(String, ExecBean, String) - Constructor for exception org.apache.hive.hcatalog.templeton.HcatException
 
HCatFieldSchema - Class in org.apache.hive.hcatalog.data.schema
 
HCatFieldSchema(String, HCatFieldSchema.Type, String) - Constructor for class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
HCatFieldSchema(String, PrimitiveTypeInfo, String) - Constructor for class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
HCatFieldSchema(String, HCatFieldSchema.Type, HCatSchema, String) - Constructor for class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
Constructor for constructing a ARRAY type or STRUCT type HCatFieldSchema, passing type and subschema
HCatFieldSchema(String, HCatFieldSchema.Type, HCatFieldSchema.Type, HCatSchema, String) - Constructor for class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
HCatFieldSchema.Category - Enum in org.apache.hive.hcatalog.data.schema
 
HCatFieldSchema.Type - Enum in org.apache.hive.hcatalog.data.schema
 
HCatFileUtil - Class in org.apache.hive.hcatalog.mapreduce
 
HCatFileUtil() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatFileUtil
 
HCatInputFormat - Class in org.apache.hive.hcatalog.mapreduce
The InputFormat to use to read data from HCatalog.
HCatInputFormat() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
 
HCatInputFormatReader - Class in org.apache.hive.hcatalog.data.transfer.impl
This reader reads via HCatInputFormat
HCatInputFormatReader(ReaderContext, int, StateProvider) - Constructor for class org.apache.hive.hcatalog.data.transfer.impl.HCatInputFormatReader
 
HCatInputFormatReader(ReadEntity, Map<String, String>) - Constructor for class org.apache.hive.hcatalog.data.transfer.impl.HCatInputFormatReader
 
HCatLoader - Class in org.apache.hive.hcatalog.pig
Pig LoadFunc to read data from HCat
HCatLoader() - Constructor for class org.apache.hive.hcatalog.pig.HCatLoader
 
HCatMapRedUtil - Class in org.apache.hive.hcatalog.mapreduce
 
HCatMapRedUtil() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatMapRedUtil
 
HCatNotificationEvent - Class in org.apache.hive.hcatalog.api
A wrapper class for NotificationEvent, so that if that class changes we can still keep this one constant for backward compatibility
HCatNotificationEvent(NotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
HCatNotificationEvent.Scope - Enum in org.apache.hive.hcatalog.api
 
HCatOutputFormat - Class in org.apache.hive.hcatalog.mapreduce
The OutputFormat to use to write data to HCatalog.
HCatOutputFormat() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
 
HCatOutputFormatWriter - Class in org.apache.hive.hcatalog.data.transfer.impl
This writer writes via HCatOutputFormat
HCatOutputFormatWriter(WriteEntity, Map<String, String>) - Constructor for class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
HCatOutputFormatWriter(WriterContext, StateProvider) - Constructor for class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
HCatPartition - Class in org.apache.hive.hcatalog.api
The HCatPartition is a wrapper around org.apache.hadoop.hive.metastore.api.Partition.
HCatPartition(HCatTable, Map<String, String>, String) - Constructor for class org.apache.hive.hcatalog.api.HCatPartition
 
HCatPartition(HCatPartition, Map<String, String>, String) - Constructor for class org.apache.hive.hcatalog.api.HCatPartition
 
HCatPartitionSpec - Class in org.apache.hive.hcatalog.api
Generalized representation of a set of HCatPartitions.
HCatPartitionSpec(HCatTable, PartitionSpecProxy) - Constructor for class org.apache.hive.hcatalog.api.HCatPartitionSpec
 
HCatPartitionSpec.HCatPartitionIterator - Class in org.apache.hive.hcatalog.api
Iterator over HCatPartitions in the HCatPartitionSpec.
HCatReader - Class in org.apache.hive.hcatalog.data.transfer
This abstract class is internal to HCatalog and abstracts away the notion of underlying system from which reads will be done.
HCatReader(ReadEntity, Map<String, String>) - Constructor for class org.apache.hive.hcatalog.data.transfer.HCatReader
This constructor will be invoked by DataTransferFactory at master node.
HCatReader(Configuration, StateProvider) - Constructor for class org.apache.hive.hcatalog.data.transfer.HCatReader
This constructor will be invoked by DataTransferFactory at slave nodes.
HCatRecord - Class in org.apache.hive.hcatalog.data
Abstract class exposing get and set semantics for basic record usage.
HCatRecord() - Constructor for class org.apache.hive.hcatalog.data.HCatRecord
 
HCatRecordable - Interface in org.apache.hive.hcatalog.data
Interface that determines whether we can implement a HCatRecord on top of it
HCatRecordObjectInspector - Class in org.apache.hive.hcatalog.data
 
HCatRecordObjectInspector(List<String>, List<ObjectInspector>) - Constructor for class org.apache.hive.hcatalog.data.HCatRecordObjectInspector
 
HCatRecordObjectInspectorFactory - Class in org.apache.hive.hcatalog.data
ObjectInspectorFactory for HCatRecordObjectInspectors (and associated helper inspectors)
HCatRecordObjectInspectorFactory() - Constructor for class org.apache.hive.hcatalog.data.HCatRecordObjectInspectorFactory
 
HCatRecordSerDe - Class in org.apache.hive.hcatalog.data
SerDe class for serializing to and from HCatRecord
HCatRecordSerDe() - Constructor for class org.apache.hive.hcatalog.data.HCatRecordSerDe
 
HCatReplicationTaskIterator - Class in org.apache.hive.hcatalog.api.repl
 
HCatReplicationTaskIterator(HCatClient, long, int, String, String) - Constructor for class org.apache.hive.hcatalog.api.repl.HCatReplicationTaskIterator
 
HCatReplicationTaskIterator(HCatClient, long, int, IMetaStoreClient.NotificationFilter) - Constructor for class org.apache.hive.hcatalog.api.repl.HCatReplicationTaskIterator
 
HCatSchema - Class in org.apache.hive.hcatalog.data.schema
HCatSchema.
HCatSchema(List<HCatFieldSchema>) - Constructor for class org.apache.hive.hcatalog.data.schema.HCatSchema
 
HCatSchemaUtils - Class in org.apache.hive.hcatalog.data.schema
 
HCatSchemaUtils() - Constructor for class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils
 
HCatSchemaUtils.CollectionBuilder - Class in org.apache.hive.hcatalog.data.schema
 
HCatSchemaUtils.HCatSchemaBuilder - Class in org.apache.hive.hcatalog.data.schema
 
HCatSchemaUtils.HCatSchemaBuilder() - Constructor for class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.HCatSchemaBuilder
 
HCatSchemaUtils.MapBuilder - Class in org.apache.hive.hcatalog.data.schema
 
HCatSchemaUtils.MapBuilder() - Constructor for class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.MapBuilder
 
HCatSemanticAnalyzer - Class in org.apache.hive.hcatalog.cli.SemanticAnalysis
 
HCatSemanticAnalyzer() - Constructor for class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzer
 
HCatSemanticAnalyzerBase - Class in org.apache.hive.hcatalog.cli.SemanticAnalysis
Base class for HCatSemanticAnalyzer hooks.
HCatSemanticAnalyzerBase() - Constructor for class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
HCatSplit - Class in org.apache.hive.hcatalog.mapreduce
The HCatSplit wrapper around the InputSplit returned by the underlying InputFormat
HCatSplit() - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatSplit
Instantiates a new hcat split.
HCatSplit(PartInfo, InputSplit) - Constructor for class org.apache.hive.hcatalog.mapreduce.HCatSplit
Instantiates a new hcat split.
HCatStorer - Class in org.apache.hive.hcatalog.pig
HCatStorer.
HCatStorer(String, String, String) - Constructor for class org.apache.hive.hcatalog.pig.HCatStorer
 
HCatStorer(String, String) - Constructor for class org.apache.hive.hcatalog.pig.HCatStorer
 
HCatStorer(String) - Constructor for class org.apache.hive.hcatalog.pig.HCatStorer
 
HCatStorer() - Constructor for class org.apache.hive.hcatalog.pig.HCatStorer
 
hcatTable() - Method in class org.apache.hive.hcatalog.api.HCatPartition
 
hcatTable(HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatPartition
 
hcatTable - Variable in class org.apache.hive.hcatalog.api.HCatPartitionSpec
 
HCatTable - Class in org.apache.hive.hcatalog.api
The HCatTable is a wrapper around org.apache.hadoop.hive.metastore.api.Table.
HCatTable(String, String) - Constructor for class org.apache.hive.hcatalog.api.HCatTable
 
HCatTable.TableAttribute - Enum in org.apache.hive.hcatalog.api
Attributes that can be compared between HCatTables.
HCatTable.Type - Enum in org.apache.hive.hcatalog.api
 
HCatTableInfo - Class in org.apache.hive.hcatalog.mapreduce
HCatTableInfo - class to communicate table information to HCatInputFormat and HCatOutputFormat
HCatUtil - Class in org.apache.hive.hcatalog.common
 
HCatUtil() - Constructor for class org.apache.hive.hcatalog.common.HCatUtil
 
HCatWriter - Class in org.apache.hive.hcatalog.data.transfer
This abstraction is internal to HCatalog.
HCatWriter(WriteEntity, Map<String, String>) - Constructor for class org.apache.hive.hcatalog.data.transfer.HCatWriter
This constructor will be used at master node
HCatWriter(Configuration, StateProvider) - Constructor for class org.apache.hive.hcatalog.data.transfer.HCatWriter
This constructor will be used at slave nodes.
hconf - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
hconf - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
HDFS_CLEANUP_INTERVAL - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
HDFS_CLEANUP_MAX_AGE - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
HDFSCleanup - Class in org.apache.hive.hcatalog.templeton.tool
This does periodic cleanup
HDFSStorage - Class in org.apache.hive.hcatalog.templeton.tool
HDFS implementation of templeton storage.
HDFSStorage() - Constructor for class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
Header() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
HEADER_COUNT - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
HEADERLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
HeaderList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
heartbeat(HeartbeatRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
heartbeat(HeartbeatRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
heartbeat(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
heartbeat(HeartbeatRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
heartbeat(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
heartbeat(long, long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
heartbeat(long, long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Send a heartbeat to indicate that the client holding these locks (if any) and that opened this transaction (if one exists) is still alive.
heartbeat(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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.
heartbeat() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Issues a heartbeat to hive metastore on the current and remaining txn ids to keep them from expiring
heartbeat_txn_range(HeartbeatTxnRangeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
heartbeat_txn_range(HeartbeatTxnRangeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
heartbeat_txn_range(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
heartbeat_txn_range(HeartbeatTxnRangeRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
heartbeat_txn_range(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
HeartBeatFailure - Exception in org.apache.hive.hcatalog.streaming
 
HeartBeatFailure(Collection<Long>, Set<Long>) - Constructor for exception org.apache.hive.hcatalog.streaming.HeartBeatFailure
 
heartbeatInterval - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
heartbeatInterval - Variable in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
HeartbeatRequest - Class in org.apache.hadoop.hive.metastore.api
 
HeartbeatRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
HeartbeatRequest(HeartbeatRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
Performs a deep copy on other.
HeartbeatRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
heartbeatTxnRange(long, long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
heartbeatTxnRange(long, long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Send heartbeats for a range of transactions.
heartbeatTxnRange(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
HeartbeatTxnRangeRequest - Class in org.apache.hadoop.hive.metastore.api
 
HeartbeatTxnRangeRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
HeartbeatTxnRangeRequest(long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
HeartbeatTxnRangeRequest(HeartbeatTxnRangeRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
Performs a deep copy on other.
HeartbeatTxnRangeRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HeartbeatTxnRangeResponse - Class in org.apache.hadoop.hive.metastore.api
 
HeartbeatTxnRangeResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
HeartbeatTxnRangeResponse(Set<Long>, Set<Long>) - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
HeartbeatTxnRangeResponse(HeartbeatTxnRangeResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
Performs a deep copy on other.
HeartbeatTxnRangeResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
help(String) - Method in class org.apache.hive.beeline.Commands
 
helper - Variable in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
helper - Variable in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
helper - Variable in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
hexArray - Static variable in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
hexStringToByte(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given a hexstring this will return the byte array corresponding to the string
HFILE_FAMILY_PATH - Static variable in class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
 
hflush(FSDataOutputStream) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
hflush(FSDataOutputStream) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
hflush(FSDataOutputStream) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Flush and make visible to other users the changes to the given stream.
HIDDEN_FILES_PATH_FILTER - Static variable in class org.apache.hadoop.hive.common.FileUtils
 
hiddenFileFilter - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
highWatermark - Variable in class org.apache.hadoop.hive.common.ValidReadTxnList
 
hintArgName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintArgName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
hintArgs() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintArgs() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
hintClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
hintItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
hintList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
hintName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
history(String) - Method in class org.apache.hive.beeline.Commands
 
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(String, String, List<String>, String, List<String>, String, String, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.Server
Run a Hive job.
HIVE_ADDED_JARS - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
HIVE_AGGR_REL_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
HIVE_ARCHIVE_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
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_COMPLETE - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
hive_db - Variable in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
HIVE_DELEGATION_KIND - Static variable in class org.apache.hadoop.hive.thrift.DelegationTokenIdentifier
 
HIVE_EXTRA_FILES - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
comma-separated list of artifacts to add to HADOOP_CLASSPATH evn var in LaunchMapper before launching Hive command
HIVE_FILTER_FIELD_LAST_ACCESS - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
HIVE_FILTER_FIELD_OWNER - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
HIVE_FILTER_FIELD_PARAMS - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
HIVE_HOME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants.PigConstants
 
HIVE_HOME_PATH - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
see webhcat-default.xml
HIVE_IO_EXCEPTION_HANDLE_CHAIN - Static variable in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
 
HIVE_JOIN_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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_metastoreConstants - Class in org.apache.hadoop.hive.metastore.api
 
hive_metastoreConstants() - Constructor for class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
HIVE_OPERATORS - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
HIVE_PATH_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
HIVE_PROPS_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
is a comma separated list of name=value pairs; In case some value is itself a comma-separated list, the comma needs to be escaped with StringUtils.ESCAPE_CHAR.
HIVE_RCFILE_IF_CLASS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HIVE_RCFILE_OF_CLASS - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
HIVE_SORT_REL_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
HIVE_SPARK_RSC_CONFIGS - Static variable in class org.apache.hive.spark.client.rpc.RpcConfiguration
 
HIVE_SPARK_TIME_CONFIGS - Static variable in class org.apache.hive.spark.client.rpc.RpcConfiguration
 
HIVE_TABLE_AS_PARQUET_SCHEMA - 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.
HiveAccumuloColumnMapping - Class in org.apache.hadoop.hive.accumulo.columns
A Hive column which maps to a column family and column qualifier pair in Accumulo
HiveAccumuloColumnMapping(String, String, ColumnEncoding, String, String) - Constructor for class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
HiveAccumuloHelper - Class in org.apache.hadoop.hive.accumulo
Helper class to hold common methods across the InputFormat, OutputFormat and StorageHandler.
HiveAccumuloHelper() - Constructor for class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
 
HiveAccumuloMapColumnMapping - Class in org.apache.hadoop.hive.accumulo.columns
ColumnMapping for combining Accumulo columns into a single Hive Map.
HiveAccumuloMapColumnMapping(String, String, ColumnEncoding, ColumnEncoding, String, String) - Constructor for class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
HiveAccumuloRecordReader - Class in org.apache.hadoop.hive.accumulo.mr
Translate the Key Value pairs from AccumuloInputFormat to a Writable for consumption by the AccumuloSerDe.
HiveAccumuloRecordReader(RecordReader<Text, PeekingIterator<Map.Entry<Key, Value>>>, int) - Constructor for class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
HiveAccumuloRowIdColumnMapping - Class in org.apache.hadoop.hive.accumulo.columns
ColumnMapping which corresponds to the Hive column which should be used as the rowID in a Mutation
HiveAccumuloRowIdColumnMapping(String, ColumnEncoding, String, String) - Constructor for class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloRowIdColumnMapping
 
HiveAccumuloSplit - Class in org.apache.hadoop.hive.accumulo.mr
Wraps RangeInputSplit into a FileSplit so Hadoop won't complain when it tries to make its own Path.
HiveAccumuloSplit() - Constructor for class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
HiveAccumuloSplit(RangeInputSplit, Path) - Constructor for class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
HiveAccumuloTableInputFormat - Class in org.apache.hadoop.hive.accumulo.mr
Wraps older InputFormat for use with Hive.
HiveAccumuloTableInputFormat() - Constructor for class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
HiveAccumuloTableOutputFormat - Class in org.apache.hadoop.hive.accumulo.mr
 
HiveAccumuloTableOutputFormat() - Constructor for class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
HiveAggregate - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
HiveAlgorithmsConf - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
 
HiveAlgorithmsConf(Double, Double) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsConf
 
HiveAlgorithmsUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
 
HiveAlterHandler - Class in org.apache.hadoop.hive.metastore
Hive specific implementation of alter
HiveAlterHandler() - Constructor for class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
hiveArchive() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
HiveAuthenticationProvider - Interface in org.apache.hadoop.hive.ql.security
HiveAuthenticationProvider is an interface for authentication.
HiveAuthFactory - Class in org.apache.hive.service.auth
This class helps in some aspects of authentication.
HiveAuthFactory(HiveConf) - Constructor for class org.apache.hive.service.auth.HiveAuthFactory
 
hiveAuthFactory - Static variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
HiveAuthFactory.AuthTypes - Enum in org.apache.hive.service.auth
 
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
 
HiveAuthorizationProviderBase.HiveProxy - Class in org.apache.hadoop.hive.ql.security.authorization
 
HiveAuthorizationProviderBase.HiveProxy(Hive) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
HiveAuthorizationProviderBase.HiveProxy() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
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
 
HiveAuthzContext - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Provides context information in authorization check call that can be used for auditing and/or authorization.
HiveAuthzContext.Builder - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveAuthzContext.Builder() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
 
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
 
HiveAuthzSessionContext - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Provides session context information.
HiveAuthzSessionContext.Builder - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveAuthzSessionContext.Builder() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
HiveAuthzSessionContext.Builder(HiveAuthzSessionContext) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
Builder that copies values from given instance of HiveAuthzSessionContext
HiveAuthzSessionContext.CLIENT_TYPE - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveBaseChar - Class in org.apache.hadoop.hive.common.type
 
HiveBaseChar() - Constructor for class org.apache.hadoop.hive.common.type.HiveBaseChar
 
HiveBaseCharWritable - Class in org.apache.hadoop.hive.serde2.io
 
HiveBaseCharWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
HiveBaseFunctionResultList<T> - Class in org.apache.hadoop.hive.ql.exec.spark
Base class for - collecting Map/Reduce function output and - providing an Iterable interface for fetching output records.
HiveBaseFunctionResultList(Iterator<T>) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
 
HiveBaseFunctionResultList.ResultIterator - Class in org.apache.hadoop.hive.ql.exec.spark
Implement Iterator interface.
HiveBaseFunctionResultList.ResultIterator() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList.ResultIterator
 
HiveBaseResultSet - Class in org.apache.hive.jdbc
Data independent base class which implements the common part of all Hive result sets.
HiveBaseResultSet() - Constructor for class org.apache.hive.jdbc.HiveBaseResultSet
 
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
 
HiveBurnInClient - Class in org.apache.hive.testutils.jdbc
 
HiveBurnInClient() - Constructor for class org.apache.hive.testutils.jdbc.HiveBurnInClient
 
HiveCalciteUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite
Generic utility functions needed for Calcite based Hive CBO.
HiveCalciteUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
HiveCalciteUtil.ConstantFinder - Class in org.apache.hadoop.hive.ql.optimizer.calcite
Walks over an expression and determines whether it is constant.
HiveCalciteUtil.ConstantFinder() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
HiveCalciteUtil.JoinLeafPredicateInfo - Class in org.apache.hadoop.hive.ql.optimizer.calcite
JoinLeafPredicateInfo represents leaf predicate in Join condition (conjuctive lement).
HiveCalciteUtil.JoinLeafPredicateInfo(SqlKind, List<List<RexNode>>, List<Set<Integer>>, List<Set<Integer>>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinLeafPredicateInfo
 
HiveCalciteUtil.JoinPredicateInfo - Class in org.apache.hadoop.hive.ql.optimizer.calcite
JoinPredicateInfo represents Join condition; JoinPredicate Info uses JoinLeafPredicateInfo to represent individual conjunctive elements in the predicate.
JoinPredicateInfo = JoinLeafPredicateInfo1 and JoinLeafPredicateInfo2...
HiveCalciteUtil.JoinPredicateInfo(List<HiveCalciteUtil.JoinLeafPredicateInfo>, List<HiveCalciteUtil.JoinLeafPredicateInfo>, List<Set<Integer>>, List<Set<Integer>>, Map<Integer, ImmutableList<HiveCalciteUtil.JoinLeafPredicateInfo>>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.JoinPredicateInfo
 
HiveCallableStatement - Class in org.apache.hive.jdbc
HiveCallableStatement.
HiveCallableStatement(Connection) - Constructor for class org.apache.hive.jdbc.HiveCallableStatement
 
HiveChar - Class in org.apache.hadoop.hive.common.type
HiveChar.
HiveChar() - Constructor for class org.apache.hadoop.hive.common.type.HiveChar
 
HiveChar(String, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveChar
 
HiveChar(HiveChar, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveChar
 
HiveCharObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
hiveCharWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
HiveCharWritable - Class in org.apache.hadoop.hive.serde2.io
HiveCharWritable.
HiveCharWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
HiveCharWritable(HiveChar) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
HiveCharWritable(HiveCharWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
HiveClusterStatus - Class in org.apache.hadoop.hive.service
 
HiveClusterStatus() - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
 
HiveClusterStatus(int, int, int, int, int, JobTrackerState) - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
 
HiveClusterStatus(HiveClusterStatus) - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
Performs a deep copy on other.
HiveClusterStatus._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveCollectionConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
HiveColumn - Class in org.apache.hadoop.hive.accumulo.columns
 
HiveColumn(String, TypeInfo) - Constructor for class org.apache.hadoop.hive.accumulo.columns.HiveColumn
 
HiveCommand - Enum in org.apache.hadoop.hive.ql.processors
 
HiveCommandOperation - Class in org.apache.hive.service.cli.operation
Executes a HiveCommand
HiveCommandOperation(HiveSession, String, CommandProcessor, Map<String, String>) - Constructor for class org.apache.hive.service.cli.operation.HiveCommandOperation
 
HiveCompactIndexInputFormat - Class in org.apache.hadoop.hive.ql.index.compact
 
HiveCompactIndexInputFormat() - Constructor for class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
HiveCompat - Class in org.apache.hive.common
 
HiveCompat() - Constructor for class org.apache.hive.common.HiveCompat
 
HiveCompat.CompatLevel - Enum in org.apache.hive.common
Enum to represent a level of backward compatibility support.
HiveConf - Class in org.apache.hadoop.hive.conf
Hive Configuration.
HiveConf() - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(Class<?>) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(Configuration, Class<?>) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(HiveConf) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
Copy constructor
hiveConf - Variable in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
hiveConf - Static variable in class org.apache.hive.hcatalog.messaging.MessageFactory
 
hiveConf - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
HiveConf.ConfVars - Enum in org.apache.hadoop.hive.conf
ConfVars.
HIVECONF_PREFIX - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
HiveConfigContext - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveConfigContext(HiveAlgorithmsConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveConfigContext
 
HiveConfUtil - Class in org.apache.hadoop.hive.conf
Hive Configuration utils
HiveConfUtil() - Constructor for class org.apache.hadoop.hive.conf.HiveConfUtil
 
HiveConnection - Class in org.apache.hive.jdbc
HiveConnection.
HiveConnection(String, Properties) - Constructor for class org.apache.hive.jdbc.HiveConnection
 
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.calcite.cost
NOTE:
1.
HiveCostModel - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Cost model interface.
HiveCostModel(Set<HiveCostModel.JoinAlgorithm>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel
 
HiveCostModel.JoinAlgorithm - Interface in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Interface for join algorithm.
HIVECOUNTERCREATEDFILES - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
HIVECOUNTERFATAL - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
HiveDatabaseMetaData - Class in org.apache.hive.jdbc
HiveDatabaseMetaData.
HiveDatabaseMetaData(HiveConnection, TCLIService.Iface, TSessionHandle) - Constructor for class org.apache.hive.jdbc.HiveDatabaseMetaData
 
HiveDataSource - Class in org.apache.hive.jdbc
HiveDataSource.
HiveDataSource() - Constructor for class org.apache.hive.jdbc.HiveDataSource
 
HiveDecimal - Class in org.apache.hadoop.hive.common.type
HiveDecimal.
HiveDecimalObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A DecimalObjectInspector inspects an Object representing a HiveDecimal.
HiveDecimalUtils - Class in org.apache.hadoop.hive.serde2.typeinfo
 
HiveDecimalUtils() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
HiveDecimalWritable - Class in org.apache.hadoop.hive.serde2.io
 
HiveDecimalWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
HiveDecimalWritable(byte[], int) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
HiveDecimalWritable(HiveDecimalWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
HiveDecimalWritable(HiveDecimal) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
HiveDefaultCostModel - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Default implementation of the cost model.
HiveDefaultCostModel.DefaultJoinAlgorithm - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Default join algorithm.
HiveDefaultCostModel.DefaultJoinAlgorithm() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
HiveDefaultRelMetadataProvider - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveDefaultRelMetadataProvider(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveDefaultRelMetadataProvider
 
HiveDelegationTokenSupport - Class in org.apache.hadoop.security.token.delegation
Workaround for serialization of AbstractDelegationTokenSecretManager.DelegationTokenInformation through package access.
HiveDelegator - Class in org.apache.hive.hcatalog.templeton
Submit a Hive job.
HiveDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.HiveDelegator
 
HiveDriver - Class in org.apache.hive.jdbc
HiveDriver.
HiveDriver() - Constructor for class org.apache.hive.jdbc.HiveDriver
 
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
 
HiveEndPoint - Class in org.apache.hive.hcatalog.streaming
Information about the hive end point (i.e.
HiveEndPoint(String, String, String, List<String>) - Constructor for class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
HiveEventCounter - Class in org.apache.hadoop.hive.shims
 
HiveEventCounter() - Constructor for class org.apache.hadoop.hive.shims.HiveEventCounter
 
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.
HiveExpandDistinctAggregatesRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Planner rule that expands distinct aggregates (such as COUNT(DISTINCT x)) from a Aggregate.
HiveExpandDistinctAggregatesRule(Class<? extends Aggregate>, RelFactories.ProjectFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveExpandDistinctAggregatesRule
 
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.
HiveFileFormatUtils.NullOutputCommitter - Class in org.apache.hadoop.hive.ql.io
 
HiveFileFormatUtils.NullOutputCommitter() - Constructor for class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
HiveFileProcessor - Class in org.apache.hadoop.hive.common.cli
HiveFileProcessor is used for processing a file consist of Hive executable statements
HiveFileProcessor() - Constructor for class org.apache.hadoop.hive.common.cli.HiveFileProcessor
 
HiveFilter - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter
 
HiveFilterJoinRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveFilterJoinRule(RelOptRuleOperand, String, boolean, RelFactories.FilterFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule
Creates a PushFilterPastJoinRule with an explicit root operand.
HiveFilterJoinRule.HiveFilterJoinMergeRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Rule that tries to push filter expressions into a join condition and into the inputs of the join.
HiveFilterJoinRule.HiveFilterJoinMergeRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinMergeRule
 
HiveFilterJoinRule.HiveFilterJoinTransposeRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveFilterJoinRule.HiveFilterJoinTransposeRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinTransposeRule
 
HiveFilterProjectTransposeRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveFilterProjectTransposeRule(Class<? extends Filter>, RelFactories.FilterFactory, Class<? extends Project>, RelFactories.ProjectFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterProjectTransposeRule
 
HiveFilterSetOpTransposeRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveFilterSetOpTransposeRule(RelFactories.FilterFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterSetOpTransposeRule
 
HiveGBOpConvUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
TODO:
1.
HiveGBOpConvUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveGBOpConvUtil
 
HiveGroupConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
HiveGroupConverter() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
HiveGroupingID - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveHarFileSystem - Class in org.apache.hadoop.hive.shims
HiveHarFileSystem - fixes issues with Hadoop's HarFileSystem
HiveHarFileSystem() - Constructor for class org.apache.hadoop.hive.shims.HiveHarFileSystem
 
HiveHBaseTableInputFormat - Class in org.apache.hadoop.hive.hbase
HiveHBaseTableInputFormat implements InputFormat for HBase storage handler tables, decorating an underlying HBase TableInputFormat with extra Hive logic such as column pruning and filter pushdown.
HiveHBaseTableInputFormat() - Constructor for class org.apache.hadoop.hive.hbase.HiveHBaseTableInputFormat
 
HiveHBaseTableOutputFormat - Class in org.apache.hadoop.hive.hbase
HiveHBaseTableOutputFormat implements HiveOutputFormat for HBase tables.
HiveHBaseTableOutputFormat() - Constructor for class org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat
 
HiveHBaseTableSnapshotInputFormat - Class in org.apache.hadoop.hive.hbase
 
HiveHBaseTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hive.hbase.HiveHBaseTableSnapshotInputFormat
 
HiveHFileOutputFormat - Class in org.apache.hadoop.hive.hbase
HiveHFileOutputFormat implements HiveOutputFormat for HFile bulk loading.
HiveHFileOutputFormat() - Constructor for class org.apache.hadoop.hive.hbase.HiveHFileOutputFormat
 
hiveHist - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
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
 
hiveHost - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
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
 
HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
 
HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
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
 
HiveInsertExchange4JoinRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Not an optimization rule.
HiveInsertExchange4JoinRule(Class<? extends RelNode>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule
 
HiveInterruptCallback - Interface in org.apache.hadoop.hive.common
 
HiveInterruptUtils - Class in org.apache.hadoop.hive.common
 
HiveInterruptUtils() - Constructor for class org.apache.hadoop.hive.common.HiveInterruptUtils
 
HiveIntervalDayTime - Class in org.apache.hadoop.hive.common.type
Day-time interval type representing an offset in days/hours/minutes/seconds, with nanosecond precision.
HiveIntervalDayTime() - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
HiveIntervalDayTime(int, int, int, int, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
HiveIntervalDayTime(long, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
HiveIntervalDayTime(BigDecimal) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
HiveIntervalDayTime(HiveIntervalDayTime) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
HiveIntervalDayTimeObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A HiveIntervalObjectInspector inspects an Object representing an Interval.
hiveIntervalDayTimeWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalDayTimeResults
 
HiveIntervalDayTimeWritable - Class in org.apache.hadoop.hive.serde2.io
 
HiveIntervalDayTimeWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
HiveIntervalDayTimeWritable(HiveIntervalDayTime) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
HiveIntervalDayTimeWritable(HiveIntervalDayTimeWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
HiveIntervalYearMonth - Class in org.apache.hadoop.hive.common.type
 
HiveIntervalYearMonth() - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
HiveIntervalYearMonth(int, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
HiveIntervalYearMonth(int) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
HiveIntervalYearMonth(HiveIntervalYearMonth) - Constructor for class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
HiveIntervalYearMonthObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A HiveIntervalObjectInspector inspects an Object representing a year-month Interval.
hiveIntervalYearMonthWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadIntervalYearMonthResults
 
HiveIntervalYearMonthWritable - Class in org.apache.hadoop.hive.serde2.io
 
HiveIntervalYearMonthWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
HiveIntervalYearMonthWritable(HiveIntervalYearMonth) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
HiveIntervalYearMonthWritable(HiveIntervalYearMonthWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
HiveIOExceptionHandler - Interface in org.apache.hadoop.hive.io
HiveIOExceptionHandler defines an interface that all io exception handler in Hive should implement.
HiveIOExceptionHandlerChain - Class in org.apache.hadoop.hive.io
An exception handler chain that process the input exception by going through all exceptions defined in this chain one by one until either one exception handler returns true or it reaches the end of the chain.
HiveIOExceptionHandlerChain() - Constructor for class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
 
HiveIOExceptionHandlerUtil - Class in org.apache.hadoop.hive.io
 
HiveIOExceptionHandlerUtil() - Constructor for class org.apache.hadoop.hive.io.HiveIOExceptionHandlerUtil
 
HiveIOExceptionNextHandleResult - Class in org.apache.hadoop.hive.io
A container to store handling results for exceptions produced in record reader's next().
HiveIOExceptionNextHandleResult() - Constructor for class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
hiveJar - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
HiveJoin - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>, HiveCostModel.JoinAlgorithm, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
HiveJoin.MapJoinStreamingRelation - Enum in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveJoinAddNotNullRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveJoinAddNotNullRule(RelFactories.FilterFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinAddNotNullRule
Creates an HiveJoinAddNotNullRule.
HiveJoinCommuteRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Planner rule that permutes the inputs of a Join, if it has a Project on top that simply swaps the fields of both inputs.
HiveJoinCommuteRule(Class<? extends Project>, Class<? extends Join>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinCommuteRule
 
HiveJoinPushTransitivePredicatesRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Planner rule that infers predicates from on a Join and creates Filters if those predicates can be pushed to its inputs.
HiveJoinPushTransitivePredicatesRule(Class<? extends Join>, RelFactories.FilterFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinPushTransitivePredicatesRule
 
HiveJoinToMultiJoinRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Rule that merges a join with multijoin/join children if the equi compared the same set of input columns.
HiveJoinToMultiJoinRule(Class<? extends Join>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinToMultiJoinRule
Creates a JoinToMultiJoinRule.
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
 
HiveLexer - Class in org.apache.hadoop.hive.ql.parse
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveLexer() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HiveLexer(CharStream) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HiveLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HiveLimit - Class in org.apache.hadoop.hive.ql.optimizer.calcite.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
 
hiveLockMgr - Variable in class org.apache.hadoop.hive.ql.Context
 
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
hiveLocks - Variable in class org.apache.hadoop.hive.ql.Context
 
HiveMapFunction - Class in org.apache.hadoop.hive.ql.exec.spark
 
HiveMapFunction(byte[], SparkReporter) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunction
 
HiveMapFunctionResultList - Class in org.apache.hadoop.hive.ql.exec.spark
 
HiveMapFunctionResultList(Iterator<Tuple2<BytesWritable, BytesWritable>>, SparkRecordHandler) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunctionResultList
Instantiate result set Iterable for Map function output.
HiveMetaDataResultSet<M> - Class in org.apache.hive.jdbc
 
HiveMetaDataResultSet(List<String>, List<String>, List<M>) - Constructor for class org.apache.hive.jdbc.HiveMetaDataResultSet
 
HiveMetaException - Exception in org.apache.hadoop.hive.metastore
 
HiveMetaException() - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(String) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(Throwable) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaHook - Interface in org.apache.hadoop.hive.metastore
HiveMetaHook defines notification methods which are invoked as part of transactions against the metastore, allowing external catalogs such as HBase to be kept in sync with Hive's metastore.
HiveMetaHookLoader - Interface in org.apache.hadoop.hive.metastore
HiveMetaHookLoader is responsible for loading a HiveMetaHook for a given table.
HiveMetaStore - Class in org.apache.hadoop.hive.metastore
TODO:pc remove application logic to a separate interface.
HiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore
 
HiveMetaStore.HiveMetastoreCli - Class in org.apache.hadoop.hive.metastore
HiveMetaStore specific CLI
HiveMetaStore.HiveMetastoreCli() - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore.HiveMetastoreCli
 
HiveMetaStore.HMSHandler - Class in org.apache.hadoop.hive.metastore
 
HiveMetaStore.HMSHandler(String) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
HiveMetaStore.HMSHandler(String, HiveConf) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
HiveMetaStore.HMSHandler(String, HiveConf, boolean) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
HiveMetaStoreClient - Class in org.apache.hadoop.hive.metastore
Hive Metastore Client.
HiveMetaStoreClient(HiveConf) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
HiveMetaStoreClient(HiveConf, HiveMetaHookLoader) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
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
 
HiveMetaStoreFsImpl - Class in org.apache.hadoop.hive.metastore
 
HiveMetaStoreFsImpl() - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
HiveMetaTool - Class in org.apache.hadoop.hive.metastore.tools
This class provides Hive admins a tool to - execute JDOQL against the metastore using DataNucleus - perform HA name node upgrade
HiveMetaTool() - Constructor for class org.apache.hadoop.hive.metastore.tools.HiveMetaTool
 
HiveMultiPartitionAuthorizationProviderBase - Class in org.apache.hadoop.hive.ql.security.authorization
Abstract class that allows authorization of operations on partition-sets.
HiveMultiPartitionAuthorizationProviderBase() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.HiveMultiPartitionAuthorizationProviderBase
 
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
 
HiveObjectPrivilege - Class in org.apache.hadoop.hive.metastore.api
 
HiveObjectPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
HiveObjectPrivilege(HiveObjectRef, String, PrincipalType, PrivilegeGrantInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
HiveObjectPrivilege(HiveObjectPrivilege) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Performs a deep copy on other.
HiveObjectPrivilege._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveObjectRef - Class in org.apache.hadoop.hive.metastore.api
 
HiveObjectRef() - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
HiveObjectRef(HiveObjectType, String, String, List<String>, String) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
HiveObjectRef(HiveObjectRef) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Performs a deep copy on other.
HiveObjectRef._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveObjectType - Enum in org.apache.hadoop.hive.metastore.api
 
HiveOnTezCostModel - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Cost model for Tez execution engine.
HiveOnTezCostModel.TezBucketJoinAlgorithm - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
BUCKET_JOIN is a hash joins where one bucket of the non streaming tables is kept in memory at the time.
HiveOnTezCostModel.TezBucketJoinAlgorithm() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
HiveOnTezCostModel.TezCommonJoinAlgorithm - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
COMMON_JOIN is Sort Merge Join.
HiveOnTezCostModel.TezCommonJoinAlgorithm() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
HiveOnTezCostModel.TezMapJoinAlgorithm - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
MAP_JOIN a hash join that keeps the whole data set of non streaming tables in memory.
HiveOnTezCostModel.TezMapJoinAlgorithm() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
HiveOnTezCostModel.TezSMBJoinAlgorithm - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
SMB_JOIN is a Sort Merge Join.
HiveOnTezCostModel.TezSMBJoinAlgorithm() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
HiveOpConverter - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
HiveOpConverter(SemanticAnalyzer, HiveConf, UnparseTranslator, Map<String, Operator<? extends OperatorDesc>>, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverter
 
HiveOpConverter.HIVEAGGOPMODE - Enum in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
HiveOpConverterPostProc - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
HiveOpConverterPostProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverterPostProc
 
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.
hiveOutputFormat - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
HivePairFlatMapFunction<T,K,V> - Class in org.apache.hadoop.hive.ql.exec.spark
 
HivePairFlatMapFunction(byte[], SparkReporter) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HivePairFlatMapFunction
 
HiveParser - Class in org.apache.hadoop.hive.ql.parse
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveParser(TokenStream) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser
 
HiveParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser
 
HiveParser.adminOptionFor_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.adminOptionFor_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.adminOptionFor_return
 
HiveParser.alterDatabaseStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterDatabaseStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseStatementSuffix_return
 
HiveParser.alterDatabaseSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterDatabaseSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixProperties_return
 
HiveParser.alterDatabaseSuffixSetOwner_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterDatabaseSuffixSetOwner_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixSetOwner_return
 
HiveParser.alterIndexStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterIndexStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterIndexStatementSuffix_return
 
HiveParser.alterProtectMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterProtectMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectMode_return
 
HiveParser.alterProtectModeMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterProtectModeMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectModeMode_return
 
HiveParser.alterStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatement_return
 
HiveParser.alterStatementChangeColPosition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementChangeColPosition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementChangeColPosition_return
 
HiveParser.alterStatementPartitionKeyType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementPartitionKeyType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementPartitionKeyType_return
 
HiveParser.alterStatementSuffixAddCol_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixAddCol_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddCol_return
 
HiveParser.alterStatementSuffixAddPartitions_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixAddPartitions_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddPartitions_return
 
HiveParser.alterStatementSuffixAddPartitionsElement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixAddPartitionsElement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixAddPartitionsElement_return
 
HiveParser.alterStatementSuffixArchive_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixArchive_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixArchive_return
 
HiveParser.alterStatementSuffixBucketNum_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixBucketNum_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixBucketNum_return
 
HiveParser.alterStatementSuffixClusterbySortby_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixClusterbySortby_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixClusterbySortby_return
 
HiveParser.alterStatementSuffixCompact_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixCompact_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixCompact_return
 
HiveParser.alterStatementSuffixDropPartitions_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixDropPartitions_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixDropPartitions_return
 
HiveParser.alterStatementSuffixExchangePartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixExchangePartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixExchangePartition_return
 
HiveParser.alterStatementSuffixFileFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixFileFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixFileFormat_return
 
HiveParser.alterStatementSuffixLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixLocation_return
 
HiveParser.alterStatementSuffixMergeFiles_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixMergeFiles_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixMergeFiles_return
 
HiveParser.alterStatementSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProperties_return
 
HiveParser.alterStatementSuffixProtectMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixProtectMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProtectMode_return
 
HiveParser.alterStatementSuffixRename_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixRename_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRename_return
 
HiveParser.alterStatementSuffixRenameCol_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixRenameCol_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenameCol_return
 
HiveParser.alterStatementSuffixRenamePart_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixRenamePart_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenamePart_return
 
HiveParser.alterStatementSuffixSerdeProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixSerdeProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixSerdeProperties_return
 
HiveParser.alterStatementSuffixSkewedby_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixSkewedby_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixSkewedby_return
 
HiveParser.alterStatementSuffixStatsPart_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixStatsPart_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixStatsPart_return
 
HiveParser.alterStatementSuffixTouch_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixTouch_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixTouch_return
 
HiveParser.alterStatementSuffixUnArchive_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixUnArchive_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUnArchive_return
 
HiveParser.alterStatementSuffixUpdateStatsCol_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixUpdateStatsCol_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUpdateStatsCol_return
 
HiveParser.alterTableStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTableStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTableStatementSuffix_return
 
HiveParser.alterTblPartitionStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTblPartitionStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffix_return
 
HiveParser.alterTblPartitionStatementSuffixSkewedLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTblPartitionStatementSuffixSkewedLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffixSkewedLocation_return
 
HiveParser.alterViewStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterViewStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewStatementSuffix_return
 
HiveParser.alterViewSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterViewSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewSuffixProperties_return
 
HiveParser.analyzeStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.analyzeStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.analyzeStatement_return
 
HiveParser.autoRebuild_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.autoRebuild_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.autoRebuild_return
 
HiveParser.body_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.body_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.body_return
 
HiveParser.colType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.colType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.colType_return
 
HiveParser.colTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.colTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.colTypeList_return
 
HiveParser.columnAssignmentClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnAssignmentClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnAssignmentClause_return
 
HiveParser.columnName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnName_return
 
HiveParser.columnNameColonType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameColonType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonType_return
 
HiveParser.columnNameColonTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameColonTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonTypeList_return
 
HiveParser.columnNameComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameComment_return
 
HiveParser.columnNameCommentList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameCommentList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameCommentList_return
 
HiveParser.columnNameList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameList_return
 
HiveParser.columnNameOrder_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameOrder_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrder_return
 
HiveParser.columnNameOrderList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameOrderList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrderList_return
 
HiveParser.columnNameType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameType_return
 
HiveParser.columnNameTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameTypeList_return
 
HiveParser.columnRefOrder_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnRefOrder_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnRefOrder_return
 
HiveParser.createDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createDatabaseStatement_return
 
HiveParser.createFunctionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createFunctionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createFunctionStatement_return
 
HiveParser.createIndexStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createIndexStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createIndexStatement_return
 
HiveParser.createMacroStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createMacroStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createMacroStatement_return
 
HiveParser.createRoleStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createRoleStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createRoleStatement_return
 
HiveParser.createTableStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createTableStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createTableStatement_return
 
HiveParser.createViewStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createViewStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createViewStatement_return
 
HiveParser.cteStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.cteStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.cteStatement_return
 
HiveParser.databaseComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.databaseComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.databaseComment_return
 
HiveParser.dbLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dbLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dbLocation_return
 
HiveParser.dbProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dbProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dbProperties_return
 
HiveParser.dbPropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dbPropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dbPropertiesList_return
 
HiveParser.ddlStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ddlStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ddlStatement_return
 
HiveParser.deleteStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.deleteStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.deleteStatement_return
 
HiveParser.descStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.descStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.descStatement_return
 
HiveParser.destination_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.destination_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.destination_return
 
HiveParser.dropDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropDatabaseStatement_return
 
HiveParser.dropFunctionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropFunctionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropFunctionStatement_return
 
HiveParser.dropIndexStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropIndexStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropIndexStatement_return
 
HiveParser.dropMacroStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropMacroStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropMacroStatement_return
 
HiveParser.dropRoleStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropRoleStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropRoleStatement_return
 
HiveParser.dropTableStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropTableStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropTableStatement_return
 
HiveParser.dropViewStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropViewStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropViewStatement_return
 
HiveParser.execStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.execStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.execStatement_return
 
HiveParser.explainOption_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.explainOption_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.explainOption_return
 
HiveParser.explainStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.explainStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.explainStatement_return
 
HiveParser.exportStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.exportStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.exportStatement_return
 
HiveParser.fileFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.fileFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.fileFormat_return
 
HiveParser.fromStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.fromStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.fromStatement_return
 
HiveParser.grantOptionFor_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.grantOptionFor_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.grantOptionFor_return
 
HiveParser.grantPrivileges_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.grantPrivileges_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.grantPrivileges_return
 
HiveParser.grantRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.grantRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.grantRole_return
 
HiveParser.ifExists_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ifExists_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ifExists_return
 
HiveParser.ifNotExists_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ifNotExists_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ifNotExists_return
 
HiveParser.ignoreProtection_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ignoreProtection_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ignoreProtection_return
 
HiveParser.importStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.importStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.importStatement_return
 
HiveParser.indexComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexComment_return
 
HiveParser.indexProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexProperties_return
 
HiveParser.indexPropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexPropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesList_return
 
HiveParser.indexPropertiesPrefixed_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexPropertiesPrefixed_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesPrefixed_return
 
HiveParser.indexTblName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexTblName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexTblName_return
 
HiveParser.insertClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.insertClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.insertClause_return
 
HiveParser.keyProperty_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.keyProperty_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.keyProperty_return
 
HiveParser.keyValueProperty_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.keyValueProperty_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.keyValueProperty_return
 
HiveParser.limitClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.limitClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.limitClause_return
 
HiveParser.listType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.listType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.listType_return
 
HiveParser.loadStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.loadStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.loadStatement_return
 
HiveParser.lockDatabase_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lockDatabase_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lockDatabase_return
 
HiveParser.lockMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lockMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lockMode_return
 
HiveParser.lockStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lockStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lockStatement_return
 
HiveParser.mapType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.mapType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.mapType_return
 
HiveParser.metastoreCheck_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.metastoreCheck_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.metastoreCheck_return
 
HiveParser.orReplace_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.orReplace_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.orReplace_return
 
HiveParser.partitionLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.partitionLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.partitionLocation_return
 
HiveParser.partTypeExpr_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.partTypeExpr_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.partTypeExpr_return
 
HiveParser.primitiveType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.primitiveType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.primitiveType_return
 
HiveParser.principalName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.principalName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.principalName_return
 
HiveParser.principalSpecification_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.principalSpecification_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.principalSpecification_return
 
HiveParser.privilegeIncludeColObject_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeIncludeColObject_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeIncludeColObject_return
 
HiveParser.privilegeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeList_return
 
HiveParser.privilegeObject_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeObject_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeObject_return
 
HiveParser.privilegeType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeType_return
 
HiveParser.privlegeDef_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privlegeDef_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privlegeDef_return
 
HiveParser.privObject_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privObject_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privObject_return
 
HiveParser.privObjectCols_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privObjectCols_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privObjectCols_return
 
HiveParser.queryStatementExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.queryStatementExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatementExpression_return
 
HiveParser.queryStatementExpressionBody_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.queryStatementExpressionBody_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatementExpressionBody_return
 
HiveParser.recordReader_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.recordReader_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.recordReader_return
 
HiveParser.recordWriter_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.recordWriter_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.recordWriter_return
 
HiveParser.regularBody_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.regularBody_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.regularBody_return
 
HiveParser.reloadFunctionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.reloadFunctionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.reloadFunctionStatement_return
 
HiveParser.replicationClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.replicationClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.replicationClause_return
 
HiveParser.resource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.resource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.resource_return
 
HiveParser.resourceList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.resourceList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.resourceList_return
 
HiveParser.resourceType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.resourceType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.resourceType_return
 
HiveParser.restrictOrCascade_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.restrictOrCascade_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.restrictOrCascade_return
 
HiveParser.revokePrivileges_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.revokePrivileges_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.revokePrivileges_return
 
HiveParser.revokeRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.revokeRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.revokeRole_return
 
HiveParser.rowFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormat_return
 
HiveParser.rowFormatDelimited_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormatDelimited_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatDelimited_return
 
HiveParser.rowFormatSerde_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormatSerde_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatSerde_return
 
HiveParser.selectStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectStatement_return
 
HiveParser.selectStatementWithCTE_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectStatementWithCTE_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectStatementWithCTE_return
 
HiveParser.setColumnsClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.setColumnsClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.setColumnsClause_return
 
HiveParser.setOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.setOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.setOperator_return
 
HiveParser.setOpSelectStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.setOpSelectStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.setOpSelectStatement_return
 
HiveParser.setRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.setRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.setRole_return
 
HiveParser.showCurrentRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showCurrentRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showCurrentRole_return
 
HiveParser.showFunctionIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showFunctionIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showFunctionIdentifier_return
 
HiveParser.showGrants_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showGrants_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showGrants_return
 
HiveParser.showRoleGrants_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showRoleGrants_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showRoleGrants_return
 
HiveParser.showRolePrincipals_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showRolePrincipals_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showRolePrincipals_return
 
HiveParser.showRoles_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showRoles_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showRoles_return
 
HiveParser.showStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showStatement_return
 
HiveParser.showStmtIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showStmtIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showStmtIdentifier_return
 
HiveParser.simpleSelectStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.simpleSelectStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.simpleSelectStatement_return
 
HiveParser.singleFromStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.singleFromStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.singleFromStatement_return
 
HiveParser.skewedColumnValue_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedColumnValue_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValue_return
 
HiveParser.skewedColumnValuePair_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedColumnValuePair_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValuePair_return
 
HiveParser.skewedColumnValuePairList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedColumnValuePairList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValuePairList_return
 
HiveParser.skewedColumnValues_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedColumnValues_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedColumnValues_return
 
HiveParser.skewedLocationMap_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedLocationMap_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocationMap_return
 
HiveParser.skewedLocations_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedLocations_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocations_return
 
HiveParser.skewedLocationsList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedLocationsList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedLocationsList_return
 
HiveParser.skewedValueElement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedValueElement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedValueElement_return
 
HiveParser.skewedValueLocationElement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.skewedValueLocationElement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.skewedValueLocationElement_return
 
HiveParser.statement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.statement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.statement_return
 
HiveParser.storedAsDirs_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.storedAsDirs_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.storedAsDirs_return
 
HiveParser.structType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.structType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.structType_return
 
HiveParser.switchDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.switchDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.switchDatabaseStatement_return
 
HiveParser.tableBuckets_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableBuckets_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableBuckets_return
 
HiveParser.tableComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableComment_return
 
HiveParser.tableFileFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableFileFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableFileFormat_return
 
HiveParser.tableLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableLocation_return
 
HiveParser.tablePartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartition_return
 
HiveParser.tablePartitionPrefix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePartitionPrefix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartitionPrefix_return
 
HiveParser.tableProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableProperties_return
 
HiveParser.tablePropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesList_return
 
HiveParser.tablePropertiesPrefixed_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePropertiesPrefixed_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesPrefixed_return
 
HiveParser.tableRowFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormat_return
 
HiveParser.tableRowFormatCollItemsIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatCollItemsIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatCollItemsIdentifier_return
 
HiveParser.tableRowFormatFieldIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatFieldIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatFieldIdentifier_return
 
HiveParser.tableRowFormatLinesIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatLinesIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatLinesIdentifier_return
 
HiveParser.tableRowFormatMapKeysIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatMapKeysIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatMapKeysIdentifier_return
 
HiveParser.tableRowNullFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowNullFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowNullFormat_return
 
HiveParser.tableSkewed_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableSkewed_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableSkewed_return
 
HiveParser.tabTypeExpr_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tabTypeExpr_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tabTypeExpr_return
 
HiveParser.truncateTableStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.truncateTableStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.truncateTableStatement_return
 
HiveParser.type_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.type_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.type_return
 
HiveParser.unionType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.unionType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.unionType_return
 
HiveParser.unlockDatabase_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.unlockDatabase_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.unlockDatabase_return
 
HiveParser.unlockStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.unlockStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.unlockStatement_return
 
HiveParser.updateStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.updateStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.updateStatement_return
 
HiveParser.viewPartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.viewPartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.viewPartition_return
 
HiveParser.withAdminOption_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.withAdminOption_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.withAdminOption_return
 
HiveParser.withClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.withClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.withClause_return
 
HiveParser.withGrantOption_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.withGrantOption_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.withGrantOption_return
 
HiveParser_FromClauseParser - Class in org.apache.hadoop.hive.ql.parse
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveParser_FromClauseParser(TokenStream, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
HiveParser_FromClauseParser(TokenStream, RecognizerSharedState, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
HiveParser_FromClauseParser.aliasList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.aliasList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.aliasList_return
 
HiveParser_FromClauseParser.expressionList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.expressionList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.expressionList_return
 
HiveParser_FromClauseParser.fromClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.fromClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.fromClause_return
 
HiveParser_FromClauseParser.fromSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.fromSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.fromSource_return
 
HiveParser_FromClauseParser.joinSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.joinSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.joinSource_return
 
HiveParser_FromClauseParser.joinToken_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.joinToken_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.joinToken_return
 
HiveParser_FromClauseParser.lateralView_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.lateralView_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.lateralView_return
 
HiveParser_FromClauseParser.partitionedTableFunction_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.partitionedTableFunction_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitionedTableFunction_return
 
HiveParser_FromClauseParser.partitioningSpec_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.partitioningSpec_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitioningSpec_return
 
HiveParser_FromClauseParser.partitionTableFunctionSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.partitionTableFunctionSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.partitionTableFunctionSource_return
 
HiveParser_FromClauseParser.searchCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.searchCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.searchCondition_return
 
HiveParser_FromClauseParser.splitSample_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.splitSample_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.splitSample_return
 
HiveParser_FromClauseParser.subQuerySource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.subQuerySource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.subQuerySource_return
 
HiveParser_FromClauseParser.tableAlias_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableAlias_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableAlias_return
 
HiveParser_FromClauseParser.tableAllColumns_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableAllColumns_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableAllColumns_return
 
HiveParser_FromClauseParser.tableBucketSample_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableBucketSample_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableBucketSample_return
 
HiveParser_FromClauseParser.tableName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableName_return
 
HiveParser_FromClauseParser.tableNameColList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableNameColList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableNameColList_return
 
HiveParser_FromClauseParser.tableOrColumn_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableOrColumn_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableOrColumn_return
 
HiveParser_FromClauseParser.tableSample_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableSample_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableSample_return
 
HiveParser_FromClauseParser.tableSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.tableSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.tableSource_return
 
HiveParser_FromClauseParser.uniqueJoinExpr_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.uniqueJoinExpr_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinExpr_return
 
HiveParser_FromClauseParser.uniqueJoinSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.uniqueJoinSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinSource_return
 
HiveParser_FromClauseParser.uniqueJoinToken_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.uniqueJoinToken_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.uniqueJoinToken_return
 
HiveParser_FromClauseParser.valueRowConstructor_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.valueRowConstructor_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valueRowConstructor_return
 
HiveParser_FromClauseParser.valuesClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.valuesClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valuesClause_return
 
HiveParser_FromClauseParser.valuesTableConstructor_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.valuesTableConstructor_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.valuesTableConstructor_return
 
HiveParser_FromClauseParser.viewName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.viewName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.viewName_return
 
HiveParser_FromClauseParser.virtualTableSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.virtualTableSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.virtualTableSource_return
 
HiveParser_FromClauseParser.whereClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_FromClauseParser.whereClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser.whereClause_return
 
HiveParser_IdentifiersParser - Class in org.apache.hadoop.hive.ql.parse
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveParser_IdentifiersParser(TokenStream, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
HiveParser_IdentifiersParser(TokenStream, RecognizerSharedState, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
HiveParser_IdentifiersParser.atomExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.atomExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.atomExpression_return
 
HiveParser_IdentifiersParser.booleanValue_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.booleanValue_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.booleanValue_return
 
HiveParser_IdentifiersParser.caseExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.caseExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.caseExpression_return
 
HiveParser_IdentifiersParser.castExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.castExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.castExpression_return
 
HiveParser_IdentifiersParser.charSetStringLiteral_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.charSetStringLiteral_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.charSetStringLiteral_return
 
HiveParser_IdentifiersParser.clusterByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.clusterByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.clusterByClause_return
 
HiveParser_IdentifiersParser.columnRefOrderInParenthese_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.columnRefOrderInParenthese_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.columnRefOrderInParenthese_return
 
HiveParser_IdentifiersParser.columnRefOrderNotInParenthese_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.columnRefOrderNotInParenthese_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.columnRefOrderNotInParenthese_return
 
HiveParser_IdentifiersParser.constant_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.constant_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.constant_return
 
HiveParser_IdentifiersParser.dateLiteral_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.dateLiteral_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dateLiteral_return
 
HiveParser_IdentifiersParser.descFuncNames_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.descFuncNames_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.descFuncNames_return
 
HiveParser_IdentifiersParser.distributeByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.distributeByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.distributeByClause_return
 
HiveParser_IdentifiersParser.dropPartitionOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.dropPartitionOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionOperator_return
 
HiveParser_IdentifiersParser.dropPartitionSpec_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.dropPartitionSpec_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionSpec_return
 
HiveParser_IdentifiersParser.dropPartitionVal_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.dropPartitionVal_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.dropPartitionVal_return
 
HiveParser_IdentifiersParser.expression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.expression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expression_return
 
HiveParser_IdentifiersParser.expressions_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.expressions_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressions_return
 
HiveParser_IdentifiersParser.expressionsInParenthese_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.expressionsInParenthese_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressionsInParenthese_return
 
HiveParser_IdentifiersParser.expressionsNotInParenthese_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.expressionsNotInParenthese_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.expressionsNotInParenthese_return
 
HiveParser_IdentifiersParser.function_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.function_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.function_return
 
HiveParser_IdentifiersParser.functionIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.functionIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.functionIdentifier_return
 
HiveParser_IdentifiersParser.functionName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.functionName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.functionName_return
 
HiveParser_IdentifiersParser.groupByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.groupByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupByClause_return
 
HiveParser_IdentifiersParser.groupingExpressionSingle_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.groupingExpressionSingle_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingExpressionSingle_return
 
HiveParser_IdentifiersParser.groupingSetExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.groupingSetExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingSetExpression_return
 
HiveParser_IdentifiersParser.groupingSetExpressionMultiple_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.groupingSetExpressionMultiple_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.groupingSetExpressionMultiple_return
 
HiveParser_IdentifiersParser.havingClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.havingClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.havingClause_return
 
HiveParser_IdentifiersParser.havingCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.havingCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.havingCondition_return
 
HiveParser_IdentifiersParser.identifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.identifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.identifier_return
 
HiveParser_IdentifiersParser.intervalLiteral_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.intervalLiteral_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.intervalLiteral_return
 
HiveParser_IdentifiersParser.intervalQualifiers_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.intervalQualifiers_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.intervalQualifiers_return
 
HiveParser_IdentifiersParser.nonReserved_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.nonReserved_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.nonReserved_return
 
HiveParser_IdentifiersParser.nullCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.nullCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.nullCondition_return
 
HiveParser_IdentifiersParser.orderByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.orderByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.orderByClause_return
 
HiveParser_IdentifiersParser.partitionByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.partitionByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionByClause_return
 
HiveParser_IdentifiersParser.partitionSpec_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.partitionSpec_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionSpec_return
 
HiveParser_IdentifiersParser.partitionVal_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.partitionVal_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.partitionVal_return
 
HiveParser_IdentifiersParser.precedenceAmpersandExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceAmpersandExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAmpersandExpression_return
 
HiveParser_IdentifiersParser.precedenceAmpersandOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceAmpersandOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAmpersandOperator_return
 
HiveParser_IdentifiersParser.precedenceAndExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceAndExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAndExpression_return
 
HiveParser_IdentifiersParser.precedenceAndOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceAndOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceAndOperator_return
 
HiveParser_IdentifiersParser.precedenceBitwiseOrExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceBitwiseOrExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseOrExpression_return
 
HiveParser_IdentifiersParser.precedenceBitwiseOrOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceBitwiseOrOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseOrOperator_return
 
HiveParser_IdentifiersParser.precedenceBitwiseXorExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceBitwiseXorExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseXorExpression_return
 
HiveParser_IdentifiersParser.precedenceBitwiseXorOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceBitwiseXorOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceBitwiseXorOperator_return
 
HiveParser_IdentifiersParser.precedenceEqualExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceEqualExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualExpression_return
 
HiveParser_IdentifiersParser.precedenceEqualNegatableOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceEqualNegatableOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualNegatableOperator_return
 
HiveParser_IdentifiersParser.precedenceEqualOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceEqualOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceEqualOperator_return
 
HiveParser_IdentifiersParser.precedenceFieldExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceFieldExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceFieldExpression_return
 
HiveParser_IdentifiersParser.precedenceNotExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceNotExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceNotExpression_return
 
HiveParser_IdentifiersParser.precedenceNotOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceNotOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceNotOperator_return
 
HiveParser_IdentifiersParser.precedenceOrExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceOrExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceOrExpression_return
 
HiveParser_IdentifiersParser.precedenceOrOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceOrOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceOrOperator_return
 
HiveParser_IdentifiersParser.precedencePlusExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedencePlusExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedencePlusExpression_return
 
HiveParser_IdentifiersParser.precedencePlusOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedencePlusOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedencePlusOperator_return
 
HiveParser_IdentifiersParser.precedenceStarExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceStarExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceStarExpression_return
 
HiveParser_IdentifiersParser.precedenceStarOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceStarOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceStarOperator_return
 
HiveParser_IdentifiersParser.precedenceUnaryOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceUnaryOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnaryOperator_return
 
HiveParser_IdentifiersParser.precedenceUnaryPrefixExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceUnaryPrefixExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnaryPrefixExpression_return
 
HiveParser_IdentifiersParser.precedenceUnarySuffixExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.precedenceUnarySuffixExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.precedenceUnarySuffixExpression_return
 
HiveParser_IdentifiersParser.principalIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.principalIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.principalIdentifier_return
 
HiveParser_IdentifiersParser.sortByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.sortByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sortByClause_return
 
HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsCastFunctionName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsCastFunctionName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsCastFunctionName_return
 
HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sql11ReservedKeywordsUsedAsIdentifier_return
 
HiveParser_IdentifiersParser.stringLiteralSequence_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.stringLiteralSequence_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.stringLiteralSequence_return
 
HiveParser_IdentifiersParser.subQueryExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.subQueryExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.subQueryExpression_return
 
HiveParser_IdentifiersParser.sysFuncNames_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.sysFuncNames_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.sysFuncNames_return
 
HiveParser_IdentifiersParser.tableOrPartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.tableOrPartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.tableOrPartition_return
 
HiveParser_IdentifiersParser.timestampLiteral_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.timestampLiteral_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.timestampLiteral_return
 
HiveParser_IdentifiersParser.whenExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_IdentifiersParser.whenExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser.whenExpression_return
 
HiveParser_SelectClauseParser - Class in org.apache.hadoop.hive.ql.parse
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveParser_SelectClauseParser(TokenStream, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
HiveParser_SelectClauseParser(TokenStream, RecognizerSharedState, HiveParser) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
HiveParser_SelectClauseParser.hintArgName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintArgName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintArgName_return
 
HiveParser_SelectClauseParser.hintArgs_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintArgs_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintArgs_return
 
HiveParser_SelectClauseParser.hintClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintClause_return
 
HiveParser_SelectClauseParser.hintItem_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintItem_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintItem_return
 
HiveParser_SelectClauseParser.hintList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintList_return
 
HiveParser_SelectClauseParser.hintName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.hintName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.hintName_return
 
HiveParser_SelectClauseParser.selectClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectClause_return
 
HiveParser_SelectClauseParser.selectExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectExpression_return
 
HiveParser_SelectClauseParser.selectExpressionList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectExpressionList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectExpressionList_return
 
HiveParser_SelectClauseParser.selectItem_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectItem_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectItem_return
 
HiveParser_SelectClauseParser.selectList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectList_return
 
HiveParser_SelectClauseParser.selectTrfmClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.selectTrfmClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.selectTrfmClause_return
 
HiveParser_SelectClauseParser.trfmClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.trfmClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.trfmClause_return
 
HiveParser_SelectClauseParser.window_clause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_clause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_clause_return
 
HiveParser_SelectClauseParser.window_defn_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_defn_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_defn_return
 
HiveParser_SelectClauseParser.window_frame_boundary_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_frame_boundary_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_boundary_return
 
HiveParser_SelectClauseParser.window_frame_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_frame_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_return
 
HiveParser_SelectClauseParser.window_frame_start_boundary_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_frame_start_boundary_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_frame_start_boundary_return
 
HiveParser_SelectClauseParser.window_range_expression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_range_expression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_range_expression_return
 
HiveParser_SelectClauseParser.window_specification_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_specification_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_specification_return
 
HiveParser_SelectClauseParser.window_value_expression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser_SelectClauseParser.window_value_expression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser.window_value_expression_return
 
HivePartitioner<K2,V2> - Interface in org.apache.hadoop.hive.ql.io
Partition keys by their Object.hashCode().
HivePartitionPruneRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HivePartitionPruneRule(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePartitionPruneRule
 
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(OutputFormat<?, ?>) - 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
 
hivePath() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
HivePreFilteringRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HivePreparedStatement - Class in org.apache.hive.jdbc
HivePreparedStatement.
HivePreparedStatement(HiveConnection, TCLIService.Iface, TSessionHandle, String) - Constructor for class org.apache.hive.jdbc.HivePreparedStatement
 
HivePreWarmProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
A simple sleep processor implementation that sleeps for the configured time in milliseconds.
HivePreWarmProcessor(ProcessorContext) - 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
 
HivePrivilege(String, List<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, and objects being used in queries.
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String, HivePrivilegeObject.HivePrivObjectActionType) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String, List<String>, String) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String, List<String>, List<String>, List<String>) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String, List<String>, List<String>, HivePrivilegeObject.HivePrivObjectActionType, List<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
Note that GLOBAL, PARTITION, COLUMN fields are populated only for Hive's old default authorization mode.
HivePrivilegeObject.HivePrivObjectActionType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
When HiveOperationType is QUERY, this action type is set so that it is possible to determine if the action type on this object is an INSERT or INSERT_OVERWRITE
HivePrivilegeObjectUtils - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Utility functions for working with HivePrivilegeObject
HivePrivilegeObjectUtils() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObjectUtils
 
HiveProject - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType, int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
Creates a HiveProject.
HiveProjectMergeRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveProjectMergeRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveProjectMergeRule
 
hiveProps() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
HiveQueryResultSet - Class in org.apache.hive.jdbc
HiveQueryResultSet.
HiveQueryResultSet(HiveQueryResultSet.Builder) - Constructor for class org.apache.hive.jdbc.HiveQueryResultSet
 
HiveQueryResultSet.Builder - Class in org.apache.hive.jdbc
 
HiveQueryResultSet.Builder(Statement) - Constructor for class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
HiveQueryResultSet.Builder(Connection) - Constructor for class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
HIVERCFILE - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
HIVERCFILE - Static variable in class org.apache.hive.service.cli.session.SessionManager
 
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
 
HiveReduceFunction - Class in org.apache.hadoop.hive.ql.exec.spark
 
HiveReduceFunction(byte[], SparkReporter) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunction
 
HiveReduceFunctionResultList - Class in org.apache.hadoop.hive.ql.exec.spark
 
HiveReduceFunctionResultList(Iterator<Tuple2<HiveKey, Iterable<BytesWritable>>>, SparkReduceRecordHandler) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunctionResultList
Instantiate result set Iterable for Reduce function output.
HiveRelCollation - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveRelCollation(ImmutableList<RelFieldCollation>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelCollation
 
HiveRelDistribution - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveRelDistribution(RelDistribution.Type, List<Integer>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
HiveRelFieldTrimmer - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
HiveRelFieldTrimmer(SqlValidator) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveRelFieldTrimmer
 
HiveRelFieldTrimmer(SqlValidator, RelFactories.ProjectFactory, RelFactories.FilterFactory, RelFactories.JoinFactory, RelFactories.SemiJoinFactory, RelFactories.SortFactory, RelFactories.AggregateFactory, RelFactories.SetOpFactory) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveRelFieldTrimmer
 
HiveRelMdCollation - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdCost - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
HiveRelMdCost supplies the implementation of cost model.
HiveRelMdCost(HiveCostModel) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost
 
HiveRelMdDistinctRowCount - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdDistribution - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdMemory - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdParallelism - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdParallelism(Double) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
HiveRelMdRowCount - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdRowCount() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
HiveRelMdSelectivity - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdSelectivity() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
HiveRelMdSize - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdUniqueKeys - Class in org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
HiveRelMdUniqueKeys() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdUniqueKeys
 
HiveRelNode - Interface in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveRelNode.Implementor - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveRelNode.Implementor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveRelNode.Implementor
 
HiveRelOptUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveRelOptUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelOptUtil
 
HiveResultSetMetaData - Class in org.apache.hive.jdbc
HiveResultSetMetaData.
HiveResultSetMetaData(List<String>, List<String>, List<JdbcColumnAttributes>) - Constructor for class org.apache.hive.jdbc.HiveResultSetMetaData
 
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
 
HiveSchemaHelper - Class in org.apache.hive.beeline
 
HiveSchemaHelper() - Constructor for class org.apache.hive.beeline.HiveSchemaHelper
 
HiveSchemaHelper.DerbyCommandParser - Class in org.apache.hive.beeline
 
HiveSchemaHelper.DerbyCommandParser(String, String, String, HiveConf) - Constructor for class org.apache.hive.beeline.HiveSchemaHelper.DerbyCommandParser
 
HiveSchemaHelper.MSSQLCommandParser - Class in org.apache.hive.beeline
 
HiveSchemaHelper.MSSQLCommandParser(String, String, String, HiveConf) - Constructor for class org.apache.hive.beeline.HiveSchemaHelper.MSSQLCommandParser
 
HiveSchemaHelper.MySqlCommandParser - Class in org.apache.hive.beeline
 
HiveSchemaHelper.MySqlCommandParser(String, String, String, HiveConf) - Constructor for class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
HiveSchemaHelper.NestedScriptParser - Interface in org.apache.hive.beeline
 
HiveSchemaHelper.NestedScriptParser.CommandType - Enum in org.apache.hive.beeline
 
HiveSchemaHelper.OracleCommandParser - Class in org.apache.hive.beeline
 
HiveSchemaHelper.OracleCommandParser(String, String, String, HiveConf) - Constructor for class org.apache.hive.beeline.HiveSchemaHelper.OracleCommandParser
 
HiveSchemaHelper.PostgresCommandParser - Class in org.apache.hive.beeline
 
HiveSchemaHelper.PostgresCommandParser(String, String, String, HiveConf) - Constructor for class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
HiveSchemaTool - Class in org.apache.hive.beeline
 
HiveSchemaTool(String) - Constructor for class org.apache.hive.beeline.HiveSchemaTool
 
HiveSchemaTool(String, HiveConf, String) - Constructor for class org.apache.hive.beeline.HiveSchemaTool
 
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
 
HiveServer2 - Class in org.apache.hive.service.server
HiveServer2.
HiveServer2() - Constructor for class org.apache.hive.service.server.HiveServer2
 
HiveServerException - Exception in org.apache.hadoop.hive.service
 
HiveServerException() - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
 
HiveServerException(String, int, String) - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
 
HiveServerException(HiveServerException) - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
Performs a deep copy on other.
HiveServerException._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveSession - Interface in org.apache.hive.service.cli.session
 
HiveSessionBase - Interface in org.apache.hive.service.cli.session
Methods that don't need to be executed under a doAs context are here.
HiveSessionHook - Interface in org.apache.hive.service.cli.session
HiveSessionHook.
HiveSessionHookContext - Interface in org.apache.hive.service.cli.session
HiveSessionHookContext.
HiveSessionHookContextImpl - Class in org.apache.hive.service.cli.session
HiveSessionHookContextImpl.
HiveSessionImpl - Class in org.apache.hive.service.cli.session
HiveSession
HiveSessionImpl(TProtocolVersion, String, String, HiveConf, String) - Constructor for class org.apache.hive.service.cli.session.HiveSessionImpl
 
HiveSessionImplwithUGI - Class in org.apache.hive.service.cli.session
HiveSessionImplwithUGI.
HiveSessionImplwithUGI(TProtocolVersion, String, String, HiveConf, String, String) - Constructor for class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
HiveSessionProxy - Class in org.apache.hive.service.cli.session
 
HiveSessionProxy(HiveSession, UserGroupInformation) - Constructor for class org.apache.hive.service.cli.session.HiveSessionProxy
 
HiveSort - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
HiveSortExchange - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveSparkClient - Interface in org.apache.hadoop.hive.ql.exec.spark
 
HiveSparkClientFactory - Class in org.apache.hadoop.hive.ql.exec.spark
 
HiveSparkClientFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.HiveSparkClientFactory
 
HiveSplitGenerator - Class in org.apache.hadoop.hive.ql.exec.tez
This class is used to generate splits inside the AM on the cluster.
HiveSplitGenerator(InputInitializerContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.HiveSplitGenerator
 
HiveSQLException - Exception in org.apache.hive.service.cli
HiveSQLException.
HiveSQLException() - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(Throwable) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String, String) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String, Throwable) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String, String, int) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String, String, Throwable) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(String, String, int, Throwable) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveSQLException(TStatus) - Constructor for exception org.apache.hive.service.cli.HiveSQLException
 
HiveStatement - Class in org.apache.hive.jdbc
HiveStatement.
HiveStatement(HiveConnection, TCLIService.Iface, TSessionHandle) - Constructor for class org.apache.hive.jdbc.HiveStatement
 
HiveStatement(HiveConnection, TCLIService.Iface, TSessionHandle, boolean) - Constructor for class org.apache.hive.jdbc.HiveStatement
 
HiveStatsUtils - Class in org.apache.hadoop.hive.common
HiveStatsUtils.
HiveStatsUtils() - Constructor for class org.apache.hadoop.hive.common.HiveStatsUtils
 
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
 
HiveStringUtils - Class in org.apache.hive.common.util
HiveStringUtils General string utils Originally copied from o.a.hadoop.util.StringUtils
HiveStringUtils() - Constructor for class org.apache.hive.common.util.HiveStringUtils
 
HiveStringUtils.TraditionalBinaryPrefix - Enum in org.apache.hive.common.util
The traditional binary prefixes, kilo, mega, ..., exa, which can be represented by a 64-bit integer.
HiveStructConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
A MapWritableGroupConverter, real converter between hive and parquet types recursively for complex types.
HiveStructConverter(GroupType, GroupType, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
HiveStructConverter(GroupType, ConverterParent, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
HiveStructConverter(GroupType, ConverterParent, int, GroupType) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
HiveTableScan - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
Relational expression representing a scan of a HiveDB collection.
HiveTableScan(RelOptCluster, RelTraitSet, RelOptHiveTable, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
Creates a HiveTableScan.
HiveTableTypeMapping - Class in org.apache.hive.service.cli.operation
HiveTableTypeMapping.
HiveTableTypeMapping() - Constructor for class org.apache.hive.service.cli.operation.HiveTableTypeMapping
 
HiveTestUtils - Class in org.apache.hive.common.util
 
HiveTestUtils() - Constructor for class org.apache.hive.common.util.HiveTestUtils
 
hiveToken(RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
Convert Calcite Types To Hive Types
HiveTotalOrderPartitioner - Class in org.apache.hadoop.hive.ql.exec
 
HiveTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
hiveTxnManager - Variable in class org.apache.hadoop.hive.ql.Context
 
HiveTxnManager - Interface in org.apache.hadoop.hive.ql.lockmgr
An interface that allows Hive to manage transactions.
HiveTypeSystemImpl - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
HiveTypeSystemImpl() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.HiveTypeSystemImpl
 
hiveTypeToSqlType(Type) - Static method in class org.apache.hive.jdbc.JdbcColumn
 
hiveTypeToSqlType(String) - Static method in class org.apache.hive.jdbc.JdbcColumn
 
HiveUnion - Class in org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
HiveUnion(RelOptCluster, RelTraitSet, List<RelNode>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion
 
HiveUtils - Class in org.apache.hadoop.hive.ql.metadata
General collection of helper functions.
HiveV1Authorizer - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveV1Authorizer(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveV1Authorizer
 
HIVEVAR_PREFIX - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
HiveVarchar - Class in org.apache.hadoop.hive.common.type
HiveVarChar.
HiveVarchar() - Constructor for class org.apache.hadoop.hive.common.type.HiveVarchar
 
HiveVarchar(String, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveVarchar
 
HiveVarchar(HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.common.type.HiveVarchar
 
HiveVarcharObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
hiveVarcharWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
HiveVarcharWritable - Class in org.apache.hadoop.hive.serde2.io
 
HiveVarcharWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
HiveVarcharWritable(HiveVarchar) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
HiveVarcharWritable(HiveVarcharWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
hiveVersion() - Method in class org.apache.hive.hcatalog.templeton.Server
Get version of hive software being run by this WebHCat server
HiveVersionAnnotation - Annotation Type in org.apache.hive.common
HiveVersionAnnotation.
HiveVersionInfo - Class in org.apache.hive.common.util
HiveVersionInfo.
HiveVersionInfo() - Constructor for class org.apache.hive.common.util.HiveVersionInfo
 
HiveVoidFunction - Class in org.apache.hadoop.hive.ql.exec.spark
Implementation of a voidFunction that does nothing.
HiveVolcanoPlanner - Class in org.apache.hadoop.hive.ql.optimizer.calcite.cost
Refinement of VolcanoPlanner for Hive.
HiveVolcanoPlanner(HiveConfigContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveVolcanoPlanner
Creates a HiveVolcanoPlanner.
HiveWindowingFixRule - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
Rule to fix windowing issue when it is done over aggregation columns (more info in HIVE-10627).
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
HookContext - Class in org.apache.hadoop.hive.ql.hooks
Hook Context keeps all the necessary information for all the hooks.
HookContext(QueryPlan, HiveConf, Map<String, ContentSummary>, String, String, String) - 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.
HS2_CLIENT_TOKEN - Static variable in class org.apache.hive.service.auth.HiveAuthFactory
 
HS2_PROXY_USER - Static variable in class org.apache.hive.service.auth.HiveAuthFactory
 
HS2TOKEN - Static variable in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
HTTP_RESPONSE - Static variable in class org.apache.hive.service.auth.HttpAuthUtils.HttpKerberosClientAction
 
HttpAuthenticationException - Exception in org.apache.hive.service.auth
 
HttpAuthenticationException(Throwable) - Constructor for exception org.apache.hive.service.auth.HttpAuthenticationException
 
HttpAuthenticationException(String) - Constructor for exception org.apache.hive.service.auth.HttpAuthenticationException
 
HttpAuthenticationException(String, Throwable) - Constructor for exception org.apache.hive.service.auth.HttpAuthenticationException
 
HttpAuthUtils - Class in org.apache.hive.service.auth
Utility functions for HTTP mode authentication.
HttpAuthUtils.HttpKerberosClientAction - Class in org.apache.hive.service.auth
We'll create an instance of this class within a doAs block so that the client's TGT credentials can be read from the Subject
HttpAuthUtils.HttpKerberosClientAction(String, String) - Constructor for class org.apache.hive.service.auth.HttpAuthUtils.HttpKerberosClientAction
 
HttpBasicAuthInterceptor - Class in org.apache.hive.jdbc
The class is instantiated with the username and password, it is then used to add header with these credentials to HTTP requests
HttpBasicAuthInterceptor(String, String, CookieStore, String, boolean, Map<String, String>) - Constructor for class org.apache.hive.jdbc.HttpBasicAuthInterceptor
 
httpCode - Variable in exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
HttpKerberosRequestInterceptor - Class in org.apache.hive.jdbc
Authentication interceptor which adds Base64 encoded payload, containing the username and kerberos service ticket, to the outgoing http request header.
HttpKerberosRequestInterceptor(String, String, String, boolean, CookieStore, String, boolean, Map<String, String>) - Constructor for class org.apache.hive.jdbc.HttpKerberosRequestInterceptor
 
HttpRequestInterceptorBase - Class in org.apache.hive.jdbc
 
HttpRequestInterceptorBase(CookieStore, String, boolean, Map<String, String>) - Constructor for class org.apache.hive.jdbc.HttpRequestInterceptorBase
 
httpServer - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
httpstatus - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
HUGE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
humanReadableInt(long) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given an integer, return a string that is in an approximate, but human readable format.
HWIAuth - Class in org.apache.hadoop.hive.hwi
Represents an authenticated user.
HWIAuth() - Constructor for class org.apache.hadoop.hive.hwi.HWIAuth
 
HWIContextListener - Class in org.apache.hadoop.hive.hwi
After getting a contextInitialized event this component starts an instance of the HiveSessionManager.
HWIContextListener() - Constructor for class org.apache.hadoop.hive.hwi.HWIContextListener
 
HWIException - Exception in org.apache.hadoop.hive.hwi
HWIException.
HWIException() - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
 
HWIException(String) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Specify an error String with the Exception.
HWIException(Throwable) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Wrap an Exception in HWIException.
HWIException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Specify an error String and wrap an Exception in HWIException.
HWIServer - Class in org.apache.hadoop.hive.hwi
This is the entry point for HWI.
HWIServer(String[]) - Constructor for class org.apache.hadoop.hive.hwi.HWIServer
 
HWISessionItem - Class in org.apache.hadoop.hive.hwi
HWISessionItem can be viewed as a wrapper for a Hive shell.
HWISessionItem(HWIAuth, String) - Constructor for class org.apache.hadoop.hive.hwi.HWISessionItem
Creates an instance of WebSessionItem, sets status to NEW.
HWISessionItem.WebSessionItemStatus - Enum in org.apache.hadoop.hive.hwi
Represents the state a session item can be in.
HWISessionManager - Class in org.apache.hadoop.hive.hwi
HiveSessionManager is a Runnable started inside a web application context.
HWISessionManager() - Constructor for class org.apache.hadoop.hive.hwi.HWISessionManager
 
HybridHashTableConf - Class in org.apache.hadoop.hive.ql.exec.persistence
This conf class is a wrapper of a list of HybridHashTableContainers and some common info shared among them, which is used in n-way join (multiple small tables are involved).
HybridHashTableConf() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
HybridHashTableContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
Hash table container that can have many partitions -- each partition has its own hashmap, as well as row container for small table and big table.
HybridHashTableContainer(Configuration, long, long, long, HybridHashTableConf) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
HybridHashTableContainer.HashPartition - Class in org.apache.hadoop.hive.ql.exec.persistence
This class encapsulates the triplet together since they are closely related to each other The triplet: hashmap (either in memory or on disk), small table container, big table container
HybridHashTableContainer.HashPartition(int, float, int, long, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 

I

i16Val(TI16Column) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
i16Val(TI16Value) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
i32Val(TI32Column) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
i32Val(TI32Value) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
i32Value(int) - Static method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
i64Val(TI64Column) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
i64Val(TI64Value) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
ICLIService - Interface in org.apache.hive.service.cli
 
id - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
id - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
id - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
id - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
id - Variable in class org.apache.hive.hcatalog.templeton.EnqueueBean
 
id - Variable in class org.apache.hive.hcatalog.templeton.JobItemBean
 
id - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
ID_COLUMN_VARCHAR_SIZE - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
ID_PATTERNS - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
IDecimalInExpr - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
Identifier - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
Identifier - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
Identifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Identifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
identifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Identifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
Identifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
identifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Identifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
IDENTIFIER - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
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
 
IdentityMapper - Class in org.apache.hadoop.hive.contrib.mr.example
Example Mapper (Identity).
IdentityProjectRemover - Class in org.apache.hadoop.hive.ql.optimizer
This optimization tries to remove SelectOperator from tree which don't do any processing except forwarding columns from its parent to its children.
IdentityProjectRemover() - Constructor for class org.apache.hadoop.hive.ql.optimizer.IdentityProjectRemover
 
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.
idToTableNameMap - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
idx - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
idx - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
IExtrapolatePartStatus - Interface in org.apache.hadoop.hive.metastore
 
IExtrapolatePartStatus.AggrType - Enum in org.apache.hadoop.hive.metastore
The sequence of aggregation function on colStats.
IExtrapolatePartStatus.ColStatType - Enum in org.apache.hadoop.hive.metastore
The sequence of colStatTypes.
ifExists - Variable in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
ifExists(boolean) - Method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
ifExists() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
IfExprCharScalarStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprCharScalarStringGroupColumn(int, HiveChar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprCharScalarStringGroupColumn
 
IfExprCharScalarStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprCharScalarStringGroupColumn
 
IfExprCharScalarStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprCharScalarStringScalar(int, HiveChar, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprCharScalarStringScalar
 
IfExprCharScalarStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprCharScalarStringScalar
 
IfExprDoubleColumnDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprDoubleColumnDoubleColumn(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
IfExprDoubleColumnDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
IfExprDoubleColumnDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprDoubleColumnDoubleScalar(int, int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
IfExprDoubleColumnDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
IfExprDoubleColumnLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprDoubleColumnLongScalar(int, int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
IfExprDoubleColumnLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
IfExprDoubleScalarDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprDoubleScalarDoubleColumn(int, double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
IfExprDoubleScalarDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
IfExprDoubleScalarDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprDoubleScalarDoubleScalar(int, double, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
IfExprDoubleScalarDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
IfExprDoubleScalarLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprDoubleScalarLongColumn(int, double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
IfExprDoubleScalarLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
IfExprDoubleScalarLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprDoubleScalarLongScalar(int, double, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
IfExprDoubleScalarLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
IfExprLongColumnDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprLongColumnDoubleScalar(int, int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
IfExprLongColumnDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
IfExprLongColumnLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprLongColumnLongColumn(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
IfExprLongColumnLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
IfExprLongColumnLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprLongColumnLongScalar(int, int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
IfExprLongColumnLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
IfExprLongScalarDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprLongScalarDoubleColumn(int, long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
IfExprLongScalarDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
IfExprLongScalarDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprLongScalarDoubleScalar(int, long, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
IfExprLongScalarDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
IfExprLongScalarLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprLongScalarLongColumn(int, long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
IfExprLongScalarLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
IfExprLongScalarLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprLongScalarLongScalar(int, long, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
IfExprLongScalarLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
IfExprStringGroupColumnCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprStringGroupColumnCharScalar(int, int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnCharScalar
 
IfExprStringGroupColumnCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnCharScalar
 
IfExprStringGroupColumnStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringGroupColumnStringGroupColumn(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringGroupColumn
 
IfExprStringGroupColumnStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringGroupColumn
 
IfExprStringGroupColumnStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprStringGroupColumnStringScalar(int, int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
IfExprStringGroupColumnStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnStringScalar
 
IfExprStringGroupColumnVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprStringGroupColumnVarCharScalar(int, int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnVarCharScalar
 
IfExprStringGroupColumnVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringGroupColumnVarCharScalar
 
IfExprStringScalarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringScalarCharScalar(int, byte[], HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarCharScalar
 
IfExprStringScalarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarCharScalar
 
IfExprStringScalarStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringScalarStringGroupColumn(int, byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
IfExprStringScalarStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringGroupColumn
 
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
 
IfExprStringScalarVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringScalarVarCharScalar(int, byte[], HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarVarCharScalar
 
IfExprStringScalarVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarVarCharScalar
 
IfExprVarCharScalarStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprVarCharScalarStringGroupColumn(int, HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringGroupColumn
 
IfExprVarCharScalarStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringGroupColumn
 
IfExprVarCharScalarStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprVarCharScalarStringScalar(int, HiveVarchar, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringScalar
 
IfExprVarCharScalarStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprVarCharScalarStringScalar
 
ifHasTransformOrUDTF() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
ifNotExists() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ifNotExists(boolean) - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc.Builder
If not exists.
ifNotExists(boolean) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
If not exists.
ifNotExists - Variable in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
ifNotExists - Variable in class org.apache.hive.hcatalog.templeton.PartitionDesc
 
ifNotExists - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
ifNotExists - Variable in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
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.
IgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
Deprecated.
 
IgnoreKeyTextOutputFormat.IgnoreKeyWriter<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
Deprecated.
 
IgnoreKeyTextOutputFormat.IgnoreKeyWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat.IgnoreKeyWriter
Deprecated.
 
ignoreProtection - Variable in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
ignoreProtection(boolean) - Method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
ignoreProtection() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
IHiveFileProcessor - Interface in org.apache.hadoop.hive.common.cli
Hive file processor is used for processing an executable Hive file
IHMSHandler - Interface in org.apache.hadoop.hive.metastore
 
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.
image - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
The string image of the token.
IMetaStoreClient - Interface in org.apache.hadoop.hive.metastore
Wrapper around hive metastore thrift api
IMetaStoreClient.IncompatibleMetastoreException - Exception in org.apache.hadoop.hive.metastore
 
IMetaStoreClient.NotificationFilter - Interface in org.apache.hadoop.hive.metastore
A filter provided by the client that determines if a given notification event should be returned.
ImpersonationFailed - Exception in org.apache.hive.hcatalog.streaming
 
ImpersonationFailed(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.ImpersonationFailed
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveLimit
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
 
implement(HiveRelNode.Implementor) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveRelNode
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
implement(HiveRelNode.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion
 
implicitConvertible(PrimitiveObjectInspector.PrimitiveCategory, PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
implicitConvertible(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
ImportCommand - Class in org.apache.hive.hcatalog.api.repl.commands
 
ImportCommand(String, String, Map<String, String>, String, boolean, long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
ImportCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
importedkeys(String) - Method in class org.apache.hive.beeline.Commands
 
ImportSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ImportSemanticAnalyzer.
ImportSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
importStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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(Explain.Level[]) - Method in enum org.apache.hadoop.hive.ql.plan.Explain.Level
 
in - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Streams to read/write from.
inBuf - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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.
Include() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
includeColumns(String, String, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcUtils
Returns selected columns as a boolean array with true value set for specified column names.
incompatFileSet - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
incrCounter(Enum<?>, long) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
incrCounter(String, String, long) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
increaseBufferSpace(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Increase buffer space enough to accommodate next element.
increment(SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
increment(long) - Method in class org.apache.hive.spark.counter.SparkCounter
 
increment(Enum<?>, long) - Method in class org.apache.hive.spark.counter.SparkCounters
 
increment(String, String, long) - Method in class org.apache.hive.spark.counter.SparkCounters
 
IncrementalRows - Class in org.apache.hive.beeline
Rows implementation which returns rows incrementally from result set without any buffering.
incrementConstructive() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
incrementCounter(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
incrementCounter(String, long) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
incrementDestructive() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Adds one to this value.
incrementDestructive() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Adds one to this value.
incrementEventId() - Method in class org.apache.hadoop.hive.metastore.model.MNotificationNextId
 
incrementFileSinkOperatorCount() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
incrementJoinCount(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
incrNumSubQueryPredicates() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
INDENT - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
Index - Class in org.apache.hadoop.hive.metastore.api
 
Index() - Constructor for class org.apache.hadoop.hive.metastore.api.Index
 
Index(String, String, String, String, int, int, String, StorageDescriptor, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.Index
 
Index(Index) - Constructor for class org.apache.hadoop.hive.metastore.api.Index
Performs a deep copy on other.
index - Variable in class org.apache.hadoop.hive.ql.hooks.LineageInfo
The map contains an index from the (datacontainer, columnname) to the dependency vector for that tuple.
INDEX - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
index - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
An index into what column we're on.
Index._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
INDEX_TABLE_CREATETIME - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndex
 
IndexAlreadyExistsException - Exception in org.apache.hadoop.hive.metastore.api
 
IndexAlreadyExistsException() - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
IndexAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
IndexAlreadyExistsException(IndexAlreadyExistsException) - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Performs a deep copy on other.
IndexAlreadyExistsException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
indexComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
indexes(String) - Method in class org.apache.hive.beeline.Commands
 
INDEXLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
indexLookup - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
Lookup vector to map from key index to primitive type index.
indexMaps - Static variable in interface org.apache.hadoop.hive.metastore.IExtrapolatePartStatus
The indexes for colstats.
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.FlatRowContainer
 
indexOf(ExprNodeDesc, ExprNodeDesc[], Operator, Operator[], boolean[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
indexOf(ExprNodeDesc, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
indexOfDomainMatch(String) - Static method in class org.apache.hive.service.ServiceUtils
 
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
 
IndexPredicateAnalyzer.FieldValidator - Interface in org.apache.hadoop.hive.ql.index
 
indexProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
indexPropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
indexPropertiesPrefixed() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
IndexSearchCondition(ExprNodeColumnDesc, String, ExprNodeConstantDesc, ExprNodeGenericFuncDesc, String[]) - Constructor for class org.apache.hadoop.hive.ql.index.IndexSearchCondition
Constructs a search condition, which takes the form
indexTblName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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<TableScanOperator, 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
 
inferAndSetPrimaryKey(long, List<ColStatistics>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Based on the provided column statistics and number of rows, this method infers if the column can be primary key.
inferForeignKey(ColStatistics, ColStatistics) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Infer foreign key relationship from given column statistics.
INFINITY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
info - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
info - Variable in class org.apache.hive.hcatalog.data.transfer.HCatReader
 
info - Variable in class org.apache.hive.hcatalog.data.transfer.HCatWriter
 
init(AccumuloHiveRow, HiveAccumuloMapColumnMapping) - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
init(AccumuloHiveRow, List<ColumnMapping>, AccumuloRowIdFactory) - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloRow
 
init(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
init(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
init(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
init(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
init(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
init(AccumuloSerDeParameters, Properties) - Method in interface org.apache.hadoop.hive.accumulo.serde.AccumuloRowIdFactory
initialize factory with properties
init(AccumuloSerDeParameters, Properties) - Method in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
init(String, String) - Method in class org.apache.hadoop.hive.ant.GenVectorCode
 
init() - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
Reset the state of the aggregation.
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
Reset the state of the aggregation.
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Reset the state.
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
init() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
init(HBaseSerDeParameters, Properties) - Method in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
init(HBaseSerDeParameters, Properties) - Method in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
init(HBaseSerDeParameters, Properties) - Method in interface org.apache.hadoop.hive.hbase.HBaseKeyFactory
initialize factory with properties
init(Configuration) - Method in class org.apache.hadoop.hive.hbase.HBaseStatsPublisher
Does the necessary HBase initializations.
init(Result, byte[], List<Boolean>) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
 
init(Result, byte[], List<Boolean>, byte[]) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
 
init(Result) - Method in class org.apache.hadoop.hive.hbase.LazyHBaseRow
Set the HBase row data(a Result writable) for this LazyStruct.
init(HBaseSerDeParameters, Configuration, Properties) - Method in class org.apache.hadoop.hive.hbase.struct.AvroHBaseValueFactory
 
init(HBaseSerDeParameters, Configuration, Properties) - Method in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
init(ByteArrayRef, int, int, String, String) - Method in class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
Set the row data for this LazyStruct.
init(HBaseSerDeParameters, Configuration, Properties) - Method in interface org.apache.hadoop.hive.hbase.struct.HBaseValueFactory
Initialize factory with properties
init() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
init() - Method in interface org.apache.hadoop.hive.metastore.IHMSHandler
 
init(AtomicBoolean, AtomicBoolean) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreThread
Initialize the thread.
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, MapredContext, 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, MapredContext, Configuration, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.exec.mr.HashTableLoader
 
init(ExecMapperContext, MapredContext, Configuration, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.exec.spark.HashTableLoader
 
init(JobConf, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMapRecordHandler
 
init(JobConf, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
init(JobConf, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
init(JobConf, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
init(ExecMapperContext, MapredContext, 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.gen.VectorUDAFAvgDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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(ExecMapperContext, MapredContext, Configuration, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTableLoader
 
init() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
init(StructObjectInspector, List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
init(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
init(VectorColumnMapping) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow
 
init(int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
init(List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
init(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
init() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
init(StructObjectInspector, List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
init(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
init(Map<Integer, String>, StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Initializes the VectorizedRowBatch context based on an scratch column type map and object inspector.
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(List<String>, int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
init(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
init(PrimitiveTypeInfo[], List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
init(List<String>, int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
init(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
init(PrimitiveTypeInfo[], List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
init(JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
init(InitContext) - 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(boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
init(boolean) - 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.CryptoProcessor
 
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.ListResourceProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.ReloadProcessor
 
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.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
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(AtomicBoolean, AtomicBoolean) - Method in class org.apache.hadoop.hive.ql.txn.compactor.Initiator
 
init(AtomicBoolean, AtomicBoolean) - 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.GenericUDAFNumericStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator
 
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
 
init(List<String>, List<ObjectInspector>, List<String>) - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
init(List<StructField>) - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector
 
init(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
 
init(DecimalTypeInfo) - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDecimalResults
 
init(CharTypeInfo) - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
init(VarcharTypeInfo) - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyArray
Set the row data for this LazyArray.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyBinary
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyBoolean
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyByte
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyDate
Initializes LazyDate object by interpreting the input bytes as a SQL date string.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyDouble
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyFloat
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveChar
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal
Initilizes LazyHiveDecimal object by interpreting the input bytes as a numeric string
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalDayTime
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalYearMonth
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveVarchar
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyLong
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Set the row data for this LazyArray.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
init(ByteArrayRef, int, int) - Method in interface org.apache.hadoop.hive.serde2.lazy.LazyObjectBase
Set the data for this LazyObjectBase.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyShort
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyString
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
Set the row data for this LazyStruct.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyTimestamp
Initilizes LazyTimestamp object by interpreting the input bytes as a JDBC timestamp string
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Set the row data for this LazyUnion.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyVoid
 
init(List<String>, List<ObjectInspector>, List<String>, byte, Text, boolean, boolean, byte) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
init(List<String>, List<ObjectInspector>, List<String>, byte, LazyObjectInspectorParameters) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
init(List<ObjectInspector>, byte, LazyObjectInspectorParameters) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Set the row data for this LazyBinaryArray.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryBinary
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryBoolean
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryByte
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryDate
Initializes LazyBinaryDate object.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryDouble
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryFloat
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveChar
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveDecimal
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveIntervalDayTime
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveIntervalYearMonth
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveVarchar
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryInteger
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryLong
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Set the row data for this LazyBinaryMap.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryShort
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryString
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
 
init(BinaryComparable) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct.SingleFieldGetter
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryTimestamp
Initializes LazyBinaryTimestamp object
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryVoid
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioBoolean
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioByte
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioDouble
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioFloat
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioInteger
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioLong
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazydio.LazyDioShort
 
init(Class<?>, ObjectInspectorFactory.ObjectInspectorOptions) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
This method is only intended to be used by Utilities class in this package.
init(List<String>, List<ObjectInspector>, List<String>) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
init(List<StructField>) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
init(Class<?>, ObjectInspectorFactory.ObjectInspectorOptions) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
This method is only intended to be used by Utilities class in this package.
init(Object, HadoopThriftAuthBridge.Server.ServerMode) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
init(Object, HadoopThriftAuthBridge.Server.ServerMode) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
 
init(Object, HadoopThriftAuthBridge.Server.ServerMode) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
init(Object, HadoopThriftAuthBridge.Server.ServerMode) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
init(String[]) - Method in class org.apache.hive.hcatalog.templeton.Main
 
init(HiveConf) - Method in class org.apache.hive.service.AbstractService
Initialize the service.
init(HiveConf) - Method in class org.apache.hive.service.BreakableService
 
init(HiveConf) - Method in class org.apache.hive.service.cli.CLIService
 
init(HiveConf) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
init(HiveConf) - Method in class org.apache.hive.service.cli.session.SessionManager
 
init(HiveConf) - Method in class org.apache.hive.service.cli.thrift.EmbeddedThriftBinaryCLIService
 
init(HiveConf) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
init(HiveConf) - Method in class org.apache.hive.service.CompositeService
 
init(HiveConf) - Method in class org.apache.hive.service.FilterService
 
init(HiveConf) - Method in class org.apache.hive.service.server.HiveServer2
 
init(HiveConf) - Method in interface org.apache.hive.service.Service
Initialize the service.
init(Service, HiveConf) - Static method in class org.apache.hive.service.ServiceOperations
Initialize a service.
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
 
initDataBuffer(boolean) - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
initEvaluators(ExprNodeEvaluator<?>[], ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.
initEvaluators(ExprNodeEvaluator<?>[], int, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.
initEvaluatorsAndReturnStruct(ExprNodeEvaluator<?>[], List<String>, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator and put the return values into a StructObjectInspector with integer field names.
initEvaluatorsAndReturnStruct(ExprNodeEvaluator[], List<List<Integer>>, List<String>, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
Initializes array of ExprNodeEvaluator.
initFiles - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-i option if any that the session has been invoked with.
initHiveExecLog4j() - Static method in class org.apache.hadoop.hive.common.LogUtils
Initialize log4j for execution mode.
initHiveLog4j() - Static method in class org.apache.hadoop.hive.common.LogUtils
Initialize log4j.
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.ProxyLocalFileSystem
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.contrib.genericudf.example.GenericUDFDBOutput
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFCount2
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFExplode2
 
initialize(InputStream, Configuration, Properties) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordReader
 
initialize(OutputStream, Configuration) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordWriter
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
Initialize the SerDe given parameters.
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.ColumnStatsUpdateTask
 
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(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(Configuration, ObjectInspector, int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Collects all the parent's output object inspectors and calls actual initialization method.
initialize(int, float, boolean, TopNHash.BinaryCollector) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
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.spark.SparkTask
 
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() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
initialize() - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
initialize() - Method in class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
initialize() - Method in class org.apache.hadoop.hive.ql.exec.tez.HiveSplitGenerator
 
initialize() - 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(Class, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.TimestampPersistenceDelegate
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileTask
 
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.stats.PartialScanTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
initialize(Table, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Initializes this object with the given variables
initialize(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
Create the list of transformations.
initialize() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
initialize(PTFQueryInputDef, StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
initialize(PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
initialize(BoundaryDef, ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
initialize(PTFExpressionDef, ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
initialize(ShapeDetails, StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
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.GenericUDFAddMonths
 
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.GenericUDFBaseArithmetic
 
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.GenericUDFCbrt
 
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.GenericUDFCurrentDate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
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.GenericUDFDateFormat
 
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.GenericUDFFactorial
 
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.GenericUDFGreatest
 
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.GenericUDFInitCap
 
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.GenericUDFLastDay
 
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.GenericUDFLevenshtein
 
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.GenericUDFMonthsBetween
 
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.GenericUDFNextDay
 
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.GenericUDFOPDTIMinus
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
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.GenericUDFSoundex
 
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.GenericUDFToIntervalDayTime
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToIntervalYearMonth
 
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.GenericUDFTrunc
 
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
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.AbstractDeserializer
Initialize the HiveDeserializer.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
Deprecated.
initialize(Configuration, Properties, Properties) - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Initialize the SerDe.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Deprecated.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.AbstractSerializer
Initialize the HiveSerializer.
initialize(Configuration, Properties, Properties) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
Initialize the SerDe given the parameters.
initialize(int) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe
 
initialize(Configuration, Properties) - Method in interface org.apache.hadoop.hive.serde2.Deserializer
Deprecated.
Initialize the HiveDeserializer.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
initialize() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
initialize() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
initialize() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Initialize the SerDe given the parameters.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Initialize the SerDe with configuration and table information.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
initialize(Configuration, Properties) - Method in interface org.apache.hadoop.hive.serde2.Serializer
Deprecated.
Initialize the HiveSerializer.
initialize(Configuration, Properties) - Method in interface org.apache.hadoop.hive.serde2.thrift.ConfigurableTProtocol
Initialize the TProtocol.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Initialize the TProtocol.
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
 
initialize(HCatSchema) - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
 
initialize(Configuration, Properties) - Method in class org.apache.hive.hcatalog.data.JsonSerDe
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
initialize(Map<String, String>) - Static method in class org.apache.hive.spark.client.SparkClientFactory
Initializes the SparkClient library.
initializeAndFoldConstants(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Initialize this GenericUDF.
initializeAndRunProcessor(Map<String, LogicalInput>, Map<String, LogicalOutput>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
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.
initializeChildren(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
initializeChildren(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
Calls initialize on each of the children with outputObjetInspector as the output row format.
initializeChildren(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Calls initialize on each of the children with outputObjetInspector as the output row format.
initializeContexts() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
initialized - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
initializeForFetch() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
initializeForFetch() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
initializeInput(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
initializeInput(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnixTimeStamp
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeMapOperator(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
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.AbstractFileMergeOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Operator specific initialization.
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
UnionOperator will transform the input rows if the inputObjInspectors from different parents are different.
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
initializeOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
 
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
 
initializeSerDe(Deserializer, Configuration, Properties, Properties) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Initializes a SerDe.
initializeSerDeWithoutErrorCheck(Deserializer, Configuration, Properties, Properties) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Initializes a SerDe.
initializeStreaming(Configuration, StructObjectInspector, boolean) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopStreaming
 
initializeStreaming(Configuration, StructObjectInspector, boolean) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMapStreaming
 
initializeStreaming(Configuration, StructObjectInspector, boolean) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
initializeStreaming(Configuration, StructObjectInspector, boolean) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
initializeVertexConf(JobConf, Context, 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
 
INITIATED_RESPONSE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
INITIATED_STATE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
initiateSparkConf(HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.HiveSparkClientFactory
 
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(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
 
initJobConf() - Method in class org.apache.hadoop.hive.ql.exec.spark.HivePairFlatMapFunction
 
initLazyFields(List<? extends StructField>) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
initNDVEstimator(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
initNDVEstimator(GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
initNextRecordReader() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
Get the record reader for the next chunk in this BucketizedHiveRecordReader.
initNextRecordReader(K) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
Get the record reader for the next chunk in this CombineFileSplit.
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.
initRowIdFactory(Configuration, Properties) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
initShutdownHook() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
 
initSpillTables(JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
initTxnMgr(HiveConf) - Method in class org.apache.hadoop.hive.ql.session.SessionState
Initialize the transaction manager.
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
 
inlineMap - Static variable in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
inner - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Are we currently on the top-level columns or parsing a column itself.
INNER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
INNER_SIGNATURE - Static variable in class org.apache.hive.hcatalog.pig.HCatLoader
 
INNER_SIGNATURE - Static variable in class org.apache.hive.hcatalog.pig.HCatStorer
 
INNER_SIGNATURE_PREFIX - Static variable in class org.apache.hive.hcatalog.pig.HCatLoader
 
INNER_SIGNATURE_PREFIX - Static variable in class org.apache.hive.hcatalog.pig.HCatStorer
 
innerIndex - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
An index into what field within a column we're on.
innerPerBatchSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
Do the per-batch setup for an inner join.
InnerStruct - Class in org.apache.hadoop.hive.serde.test
 
InnerStruct() - Constructor for class org.apache.hadoop.hive.serde.test.InnerStruct
 
InnerStruct(int) - Constructor for class org.apache.hadoop.hive.serde.test.InnerStruct
 
InnerStruct(InnerStruct) - Constructor for class org.apache.hadoop.hive.serde.test.InnerStruct
Performs a deep copy on other.
InnerStruct._Fields - Enum in org.apache.hadoop.hive.serde.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
innerTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The transport being wrapped.
inProtocol - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
input - Variable in class org.apache.hadoop.hive.ant.GetVersionPref
The input string that contains the version string.
INPUT_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
INPUT_REGEX - Static variable in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
INPUT_REGEX - Static variable in class org.apache.hadoop.hive.serde2.RegexSerDe
 
INPUT_REGEX_CASE_SENSITIVE - Static variable in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
INPUT_REGEX_CASE_SENSITIVE - Static variable in class org.apache.hadoop.hive.serde2.RegexSerDe
 
INPUT_SEPERATOR - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
input_stream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
INPUT_SUMMARY - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
inputAliases - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
InputByteBuffer - Class in org.apache.hadoop.hive.serde2.binarysortable
This class is much more efficient than ByteArrayInputStream because none of the methods are synchronized.
InputByteBuffer() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
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.
inputFileFormat(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for InputFormat class.
inputFormat - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
InputFormatChecker - Interface in org.apache.hadoop.hive.ql.io
Check for validity of the input files.
inputFormatClassName - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
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
 
InputJobInfo - Class in org.apache.hive.hcatalog.mapreduce
Container for metadata read from the metadata server.
InputMetrics - Class in org.apache.hive.spark.client.metrics
Metrics pertaining to reading input data.
InputMetrics(DataReadMethod, long) - Constructor for class org.apache.hive.spark.client.metrics.InputMetrics
 
InputMetrics(TaskMetrics) - Constructor for class org.apache.hive.spark.client.metrics.InputMetrics
 
inputMetrics - Variable in class org.apache.hive.spark.client.metrics.Metrics
If tasks read from a HadoopRDD or from persisted data, metrics on how much data was read.
inputObjInspectors - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
inputOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
inputOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
inputOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
inputOIs - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseDTI
 
inputPath - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
inputs - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
ReadEntitites that are passed to the hooks.
inputs - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
inputs - Variable in class org.apache.hadoop.hive.ql.plan.DDLWork
ReadEntitites that are passed to the hooks.
inputs - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
ReadEntitites that are passed to the hooks.
inputSelected - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
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
 
inputSplits - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
inputStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
inputTypes - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
More detailed input types, such as date and timestamp.
inRange(String, Object, Object) - Method in enum org.apache.hadoop.hive.conf.Validator.TYPE
 
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
 
insertAfter(DiskRangeList) - Method in class org.apache.hadoop.hive.common.DiskRangeList
Inserts an element after current in the list.
insertClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
insertData(InsertEventRequestData) - Static method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
InsertEvent - Class in org.apache.hadoop.hive.metastore.events
 
InsertEvent(String, String, List<String>, List<String>, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.InsertEvent
 
InsertEventRequestData - Class in org.apache.hadoop.hive.metastore.api
 
InsertEventRequestData() - Constructor for class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
InsertEventRequestData(List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
InsertEventRequestData(InsertEventRequestData) - Constructor for class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
Performs a deep copy on other.
InsertEventRequestData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InsertMessage - Class in org.apache.hive.hcatalog.messaging
HCat message sent when an insert is done to a table or partition.
InsertMessage() - Constructor for class org.apache.hive.hcatalog.messaging.InsertMessage
 
insertOperatorBetween(Operator<?>, Operator<?>, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
insertPartAfter(DiskRangeList) - Method in class org.apache.hadoop.hive.common.DiskRangeList
Inserts an intersecting range after current in the list and adjusts offset accordingly.
insertPartBefore(DiskRangeList) - Method in class org.apache.hadoop.hive.common.DiskRangeList
Inserts an intersecting range before current in the list and adjusts offset accordingly.
InsertReplicationTask - Class in org.apache.hive.hcatalog.api.repl.exim
 
InsertReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.exim.InsertReplicationTask
 
insertRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
insertsAreDetected(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
insideMRJob(JobConf) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Determine if we're being executed from within an MR job or as part of a select * statement.
InspectableObject - Class in org.apache.hadoop.hive.serde2.objectinspector
Simple wrapper of object with ObjectInspector.
InspectableObject() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
InspectableObject(Object, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
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.
inspector - Variable in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
instance() - Static method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveGroupingID
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveExpandDistinctAggregatesRule
The default instance of the rule; operates only on logical expressions.
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinAddNotNullRule
The singleton.
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinCommuteRule
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinPushTransitivePredicatesRule
The singleton.
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinToMultiJoinRule
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePreFilteringRule
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveProjectMergeRule
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveWindowingFixRule
 
INSTANCE_NAME - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
InstanceCache<SeedObject,Instance> - Class in org.apache.hadoop.hive.serde2.avro
Cache for objects whose creation only depends on some other set of objects and therefore can be used against other equivalent versions of those objects.
InstanceCache() - Constructor for class org.apache.hadoop.hive.serde2.avro.InstanceCache
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.CommonTokenDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.DatePersistenceDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.PathDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
instantiateDTIUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseArithmetic
Instantiate date-time/interval version of the arithmetic UDF
instantiateDTIUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMinus
 
instantiateDTIUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPPlus
 
instantiateNumericUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseArithmetic
Instantiate numeric version of the arithmetic UDF
instantiateNumericUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMinus
 
instantiateNumericUDF() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPPlus
 
InStream - Class in org.apache.hadoop.hive.ql.io.orc
 
InStream(String, long) - Constructor for class org.apache.hadoop.hive.ql.io.orc.InStream
 
INT_COUNT - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
Number of ints to store this object.
INT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
INT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
INT = 3;
intArrayToRangesString(int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
IntCompare - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Set of comparison operations over a integer constant.
IntCompare() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
INTEGER - Static variable in class org.apache.hive.hcatalog.data.DataType
 
integerBitmask(int) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
IntegerColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for all of the integer columns, such as byte, short, int, and long.
integerFlag(int) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
IntegralLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
IntegralLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
IntegralTypes - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
InterfaceAudience - Class in org.apache.hadoop.hive.common.classification
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.hadoop.hive.common.classification
Intended only for the project(s) specified in the annotation
InterfaceAudience.Private - Annotation Type in org.apache.hadoop.hive.common.classification
Intended for use only within Hive itself.
InterfaceAudience.Public - Annotation Type in org.apache.hadoop.hive.common.classification
Intended for use by any project or application.
InterfaceStability - Class in org.apache.hadoop.hive.common.classification
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.hadoop.hive.common.classification.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.apache.hadoop.hive.common.classification
Evolving, but can break compatibility at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.hadoop.hive.common.classification
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
InterfaceStability.Unstable - Annotation Type in org.apache.hadoop.hive.common.classification
No guarantee is provided as to reliability or stability across any level of release granularity.
intermediate - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
intern(Interner<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
intern(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Return the internalized string, or null if the given string is null.
intern(List<String>) - Static method in class org.apache.hive.common.util.HiveStringUtils
Return an interned list with identical contents as the given list.
intern(Map<String, String>) - Static method in class org.apache.hive.common.util.HiveStringUtils
Return an interned map with identical contents as the given map.
internalEquals(ColumnInfo) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
internalForward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
internalForward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
'forwards' the (row-mode) record into the (vectorized) output batch
internalForward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
internalInitialize() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Sets the internal separator patterns and creates the internal tokenizer.
internalRead() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
internalWriteString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
internTable(Interner<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
internTableDesc(Task<?>, Interner<TableDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
interrupt() - Method in interface org.apache.hadoop.hive.common.HiveInterruptCallback
Request interrupting of the processing
interrupt() - Static method in class org.apache.hadoop.hive.common.HiveInterruptUtils
Request interruption of current hive command
interval - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
interval - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
INTERVAL_DAY_TIME_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
INTERVAL_YEAR_MONTH_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
intervalArg1Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
intervalArg1Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
intervalArg2Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
intervalArg2Idx - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
IntervalDayTimeColAddDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
IntervalDayTimeColAddDateColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
IntervalDayTimeColAddDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
IntervalDayTimeColAddDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
IntervalDayTimeColAddDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
IntervalDayTimeColAddDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
IntervalDayTimeColAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
IntervalDayTimeColAddIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeColumn
 
IntervalDayTimeColAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeColumn
 
IntervalDayTimeColAddIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
IntervalDayTimeColAddIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeScalar
 
IntervalDayTimeColAddIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddIntervalDayTimeScalar
 
IntervalDayTimeColAddTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
IntervalDayTimeColAddTimestampColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampColumn
 
IntervalDayTimeColAddTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampColumn
 
IntervalDayTimeColAddTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
IntervalDayTimeColAddTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampScalar
 
IntervalDayTimeColAddTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddTimestampScalar
 
IntervalDayTimeColEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColEqualIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColEqualIntervalDayTimeScalar
 
IntervalDayTimeColEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColEqualIntervalDayTimeScalar
 
IntervalDayTimeColGreaterEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColGreaterEqualIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
IntervalDayTimeColGreaterEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterEqualIntervalDayTimeScalar
 
IntervalDayTimeColGreaterIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColGreaterIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterIntervalDayTimeScalar
 
IntervalDayTimeColGreaterIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColGreaterIntervalDayTimeScalar
 
IntervalDayTimeColLessEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColLessEqualIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessEqualIntervalDayTimeScalar
 
IntervalDayTimeColLessEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessEqualIntervalDayTimeScalar
 
IntervalDayTimeColLessIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColLessIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessIntervalDayTimeScalar
 
IntervalDayTimeColLessIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColLessIntervalDayTimeScalar
 
IntervalDayTimeColNotEqualIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalDayTimeColNotEqualIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColNotEqualIntervalDayTimeScalar
 
IntervalDayTimeColNotEqualIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColNotEqualIntervalDayTimeScalar
 
IntervalDayTimeColSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
IntervalDayTimeColSubtractIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeColumn
 
IntervalDayTimeColSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeColumn
 
IntervalDayTimeColSubtractIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
IntervalDayTimeColSubtractIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeScalar
 
IntervalDayTimeColSubtractIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColSubtractIntervalDayTimeScalar
 
intervalDayTimeResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
intervalDayTimeResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
IntervalDayTimeScalarAddDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
IntervalDayTimeScalarAddDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
IntervalDayTimeScalarAddDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
IntervalDayTimeScalarAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
IntervalDayTimeScalarAddIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddIntervalDayTimeColumn
 
IntervalDayTimeScalarAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddIntervalDayTimeColumn
 
IntervalDayTimeScalarAddTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
IntervalDayTimeScalarAddTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddTimestampColumn
 
IntervalDayTimeScalarAddTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddTimestampColumn
 
IntervalDayTimeScalarEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarEqualIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarGreaterIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarGreaterIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
IntervalDayTimeScalarGreaterIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarGreaterIntervalDayTimeColumn
 
IntervalDayTimeScalarLessEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarLessEqualIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarLessEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarLessIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarLessIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessIntervalDayTimeColumn
 
IntervalDayTimeScalarLessIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarLessIntervalDayTimeColumn
 
IntervalDayTimeScalarNotEqualIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalDayTimeScalarNotEqualIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarNotEqualIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarNotEqualIntervalDayTimeColumn
 
IntervalDayTimeScalarSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
IntervalDayTimeScalarSubtractIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarSubtractIntervalDayTimeColumn
 
IntervalDayTimeScalarSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarSubtractIntervalDayTimeColumn
 
intervalDayTimeTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
intervalDayTimeTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
intervalDayTimeWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
intervalLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
intervalLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
intervalQualifiers() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
intervalQualifiers() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
intervalValue - Variable in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
intervalValue - Variable in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
IntervalYearMonthColAddDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalColumnArithmeticDateTimeColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
IntervalYearMonthColAddDateColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
IntervalYearMonthColAddDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
IntervalYearMonthColAddDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalColumnArithmeticDateTimeScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
IntervalYearMonthColAddDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
IntervalYearMonthColAddDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
IntervalYearMonthColAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
IntervalYearMonthColAddIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthColumn
 
IntervalYearMonthColAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthColumn
 
IntervalYearMonthColAddIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
IntervalYearMonthColAddIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthScalar
 
IntervalYearMonthColAddIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddIntervalYearMonthScalar
 
IntervalYearMonthColAddTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalColumnArithmeticDateTimeColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
IntervalYearMonthColAddTimestampColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
IntervalYearMonthColAddTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
IntervalYearMonthColAddTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalColumnArithmeticDateTimeScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
IntervalYearMonthColAddTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
IntervalYearMonthColAddTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
IntervalYearMonthColEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColEqualIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColEqualIntervalYearMonthScalar
 
IntervalYearMonthColEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColEqualIntervalYearMonthScalar
 
IntervalYearMonthColGreaterEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColGreaterEqualIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
IntervalYearMonthColGreaterEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterEqualIntervalYearMonthScalar
 
IntervalYearMonthColGreaterIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColGreaterIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterIntervalYearMonthScalar
 
IntervalYearMonthColGreaterIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColGreaterIntervalYearMonthScalar
 
IntervalYearMonthColLessEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColLessEqualIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessEqualIntervalYearMonthScalar
 
IntervalYearMonthColLessEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessEqualIntervalYearMonthScalar
 
IntervalYearMonthColLessIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColLessIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessIntervalYearMonthScalar
 
IntervalYearMonthColLessIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColLessIntervalYearMonthScalar
 
IntervalYearMonthColNotEqualIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnCompareScalar.txt, which covers comparison expressions between a datetime/interval column and a scalar of the same type.
IntervalYearMonthColNotEqualIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColNotEqualIntervalYearMonthScalar
 
IntervalYearMonthColNotEqualIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColNotEqualIntervalYearMonthScalar
 
IntervalYearMonthColSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
IntervalYearMonthColSubtractIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthColumn
 
IntervalYearMonthColSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthColumn
 
IntervalYearMonthColSubtractIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
IntervalYearMonthColSubtractIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthScalar
 
IntervalYearMonthColSubtractIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColSubtractIntervalYearMonthScalar
 
intervalYearMonthResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
intervalYearMonthResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
IntervalYearMonthScalarAddDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalScalarArithmeticDateTimeColumnWithConvert.txt.
IntervalYearMonthScalarAddDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
IntervalYearMonthScalarAddDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
IntervalYearMonthScalarAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
IntervalYearMonthScalarAddIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddIntervalYearMonthColumn
 
IntervalYearMonthScalarAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddIntervalYearMonthColumn
 
IntervalYearMonthScalarAddTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template IntervalScalarArithmeticDateTimeColumnWithConvert.txt.
IntervalYearMonthScalarAddTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
IntervalYearMonthScalarAddTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
IntervalYearMonthScalarEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarEqualIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarGreaterIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarGreaterIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
IntervalYearMonthScalarGreaterIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarGreaterIntervalYearMonthColumn
 
IntervalYearMonthScalarLessEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarLessEqualIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarLessEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarLessIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarLessIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessIntervalYearMonthColumn
 
IntervalYearMonthScalarLessIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarLessIntervalYearMonthColumn
 
IntervalYearMonthScalarNotEqualIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarCompareColumn.txt, which covers comparison expressions between a datetime/interval scalar and a column of the same type.
IntervalYearMonthScalarNotEqualIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarNotEqualIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarNotEqualIntervalYearMonthColumn
 
IntervalYearMonthScalarSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
IntervalYearMonthScalarSubtractIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarSubtractIntervalYearMonthColumn
 
IntervalYearMonthScalarSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarSubtractIntervalYearMonthColumn
 
intervalYearMonthTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
intervalYearMonthTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
intervalYearMonthWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
IntObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A IntObjectInspector inspects an Object representing an Integer.
inTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
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
 
INTSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
IntString - Class in org.apache.hadoop.hive.serde2.thrift.test
 
IntString() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
IntString(int, String, int) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
IntString(IntString) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.IntString
Performs a deep copy on other.
IntString._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
intTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
intTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
intValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Converts this Decimal128 to an int.
intValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
intValue() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
intValue(int) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
InvalidColumn - Exception in org.apache.hive.hcatalog.streaming
 
InvalidColumn(String) - Constructor for exception org.apache.hive.hcatalog.streaming.InvalidColumn
 
InvalidColumnMappingException - Exception in org.apache.hadoop.hive.accumulo.columns
 
InvalidColumnMappingException() - Constructor for exception org.apache.hadoop.hive.accumulo.columns.InvalidColumnMappingException
 
InvalidColumnMappingException(String) - Constructor for exception org.apache.hadoop.hive.accumulo.columns.InvalidColumnMappingException
 
InvalidColumnMappingException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.columns.InvalidColumnMappingException
 
InvalidColumnMappingException(Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.columns.InvalidColumnMappingException
 
InvalidInputException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidInputException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
InvalidInputException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
InvalidInputException(InvalidInputException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidInputException
Performs a deep copy on other.
InvalidInputException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InvalidObjectException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidObjectException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
InvalidObjectException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
InvalidObjectException(InvalidObjectException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Performs a deep copy on other.
InvalidObjectException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InvalidOperationException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidOperationException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
InvalidOperationException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
InvalidOperationException(InvalidOperationException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Performs a deep copy on other.
InvalidOperationException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InvalidPartition - Exception in org.apache.hive.hcatalog.streaming
 
InvalidPartition(String, String) - Constructor for exception org.apache.hive.hcatalog.streaming.InvalidPartition
 
InvalidPartitionException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidPartitionException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
InvalidPartitionException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
InvalidPartitionException(InvalidPartitionException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
Performs a deep copy on other.
InvalidPartitionException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InvalidTable - Exception in org.apache.hive.hcatalog.streaming
 
InvalidTable(String, String) - Constructor for exception org.apache.hive.hcatalog.streaming.InvalidTable
 
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
 
InvalidTrasactionState - Exception in org.apache.hive.hcatalog.streaming
 
InvalidTrasactionState(String) - Constructor for exception org.apache.hive.hcatalog.streaming.InvalidTrasactionState
 
INVERSE_POWER_FIVES_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
1/5^x, scaled to 128bits (in other words, 2^128/5^x).
INVERSE_POWER_TENS_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
1/10^x, scaled to 128bits, also word-shifted for better accuracy.
INVERSE_POWER_TENS_INT128_WORD_SHIFTS - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
number of words shifted up in each INVERSE_POWER_TENS_INT128.
invert() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
invert() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUtcTimestamp
 
invertedWorkGraph - Variable in class org.apache.hadoop.hive.ql.plan.SparkWork
 
invoke(String, Object[], String[]) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hive.metastore.RawStoreProxy
 
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hive.metastore.RetryingHMSHandler
 
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
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
 
invoke(Object, Method, Object[]) - Method in class org.apache.hive.service.cli.session.HiveSessionProxy
 
invokeRewriteQueryProc() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
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
 
ioi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
ioi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
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
 
iprot_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
IS_ARCHIVED - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
IS_IMMUTABLE - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
isAbort() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
isAbort() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
isAbort() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
isAcid(Path, Configuration) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Is the given directory in ACID format?
isAcidTable(Table) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
isActionable() - Method in class org.apache.hive.hcatalog.api.repl.NoopReplicationTask
 
isActionable() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Returns true if this ReplicationTask is prepared with all info it needs, and is ready to be used
isActionPermittedForFileHierarchy(FileSystem, FileStatus, String, FsAction) - Static method in class org.apache.hadoop.hive.common.FileUtils
Check if user userName has permissions to perform the given FsAction action on all files under the file whose FileStatus fileStatus is provided
isActiveTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
isAfterLast() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isAggFuncIsNotCount() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isAggParameterException() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isAggregate() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
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
 
isAllConstants(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
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
 
isAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isAnalyzeRewrite() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isAnalyzeRewrite() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isAnsiSqlArithmetic() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
isAppendTaskType() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isApplicable(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Tests if an ASTNode is a Replication Specification
isArchived(Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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
 
isAuthorize() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isAuthV2Enabled() - Method in class org.apache.hive.service.cli.operation.MetadataOperation
 
isAutoCommit() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
isAutoIncrement(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isAutoIncrement() - Method in enum org.apache.hive.service.cli.Type
Can this type be used for an auto-increment value?
isAutoParallel() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isAutoReduce() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
isAutoReduceParallelism() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
isAvailable() - Method in interface org.apache.hadoop.hive.ql.io.orc.DirectDecompressionCodec
 
isBeforeFirst() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isBeforeFirst() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
isBigTablePartitioned() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
isBigTableWork() - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
isBinarySearching() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
isBlockedFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isBlockPointer() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
isBucketedInput() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate
 
isBucketMapJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
isBuiltIn() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isBuiltInFunc(Class<?>) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
isBuiltInFuncExpr(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
isCanceled() - Method in class org.apache.hive.service.cli.operation.Operation
 
isCandidate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns true if the specified expression is pushdown candidate else false.
isCappedCountAvailable() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
isCappedCountAvailable() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
isCappedCountAvailable() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
isCarryForwardNames() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
isCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
isCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
isCasdade() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
isCaseSensitive() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
isCaseSensitive(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isCaseSensitive() - Method in enum org.apache.hive.service.cli.Type
Is the type case sensitive?
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
 
isCatalogAtStart() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
isCategory(ObjectInspector.Category) - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
isCategory(PrimitiveObjectInspector.PrimitiveCategory) - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
isCboSucceeded() - Method in class org.apache.hadoop.hive.ql.Context
 
isClearAggregatorStats() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
isClosed() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isClosed() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
isClosed() - Method in class org.apache.hive.jdbc.HiveConnection
 
isClosed() - Method in class org.apache.hive.jdbc.HiveStatement
 
isCloseOnCompletion() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
isCloseOnCompletion() - Method in class org.apache.hive.jdbc.HiveStatement
 
isCollectionType() - Method in enum org.apache.hive.service.cli.Type
 
isCollectRWStats - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
isColumnOnly(VectorExpression) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
isComparable() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
isCompatibleWith(HiveConf) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
isCompatibleWith(HiveConf) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Returns whether current client is compatible with conf argument or not
isComplete() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
isComplete() - Method in class org.apache.hive.service.auth.PlainSaslServer
 
isComplex() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
isComplexType() - Method in enum org.apache.hive.service.cli.Type
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
isCompressed - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
isConfLookupNeeded() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
isConnectionHealthy() - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Send a dummy message to probe if the JMS connection is healthy
isConstant() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
isConstantObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
isConstantParameterInAggregationParameters(String, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Check if the given internalName represents a constant parameter in aggregation parameters of an aggregation tree.
isConversionRequiredForComparison(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Given two types, determine whether conversion needs to occur to compare the two types.
isConvertedAutomaticallySMBJoin() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
isCopyFile(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
isCTAS() - Method in class org.apache.hadoop.hive.ql.parse.QB
Whether this QB is for a CREATE-TABLE-AS-SELECT.
isCTAS() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isCurrency(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isCustomInputType(TezWork.VertexType) - Static method in enum org.apache.hadoop.hive.ql.plan.TezWork.VertexType
 
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
 
isDefaultNameNode(HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Checks if current hive script was executed with non-default namenode
isDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
isDefinitelyWritable(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isDelete(V) - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat.RawReader
 
isDelete(OrcStruct) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
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(RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
isDeterministic(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Return false if the expression has any non deterministic function
isDeterministic() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
isDeterministic() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
isDir(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
isDirect() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
isDirectory(FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
isDirectory(FileStatus) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
isDirectory(FileStatus) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Check whether file is directory.
isDirEmpty(FileSystem, Path) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Utility method that determines if a specified directory already has contents (non-hidden files) or not - useful to determine if an immutable table already has contents, for example.
isDiscarded() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
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.
isdone - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
isDynamicPartitioningUsed() - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Returns whether or not Dynamic Partitioning is used
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
isEmbedded - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
isEmbeddedMetaStore(String) - Static method in class org.apache.hadoop.hive.conf.HiveConfUtil
Check if metastore is being used in embedded mode.
isEmbeddedMode() - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
isEmpty(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
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
 
isEnable() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
isEnabled - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
isEnabled() - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
isEnforceSort() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isEof() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
 
isEof() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
isEof() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
isEof() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
isEof() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
isEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
isEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
isEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
isEqual(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
isEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
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.HiveDecimalValueBoundaryScanner
 
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
 
isEqual(long, int, long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Compares two parts of the buffer with each other.
isEqual(byte[], int, long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Compares part of the buffer with a part of an external byte array.
isEqual(byte[], int, int, long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Compares part of the buffer with a part of an external byte array.
isEqWithEpsilon(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
isError(Map) - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Check if this is an error doc.
isErrorOnSrcEmpty() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
isEscaped() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
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).
isExcluded() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
isExecutable(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
isExecutable(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
isExecutable(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
isExecutable(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
isExecutable(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
isExecutable(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
isExisted(ExprNodeDesc, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
isExit() - Method in class org.apache.hive.beeline.BeeLine
 
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
 
isExtendedAclEnabled(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
isExtendedBooleanLiteral() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
isExtendedBooleanLiteral() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
isExtendedBooleanLiteral() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
isExtendedLiteral() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBooleanObjectInspector
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
isExternalTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
isExternalTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Determines whether a table is an external table.
isFailed() - Method in class org.apache.hive.service.cli.operation.Operation
 
isFetchFrom(FileSinkDesc) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
isFetchingTable() - Method in class org.apache.hadoop.hive.ql.Driver
 
isFetchSource() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isFileInHDFS(FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims
Checks if file is in HDFS filesystem.
isFiltered(Object, List<ExprNodeEvaluator>, List<ObjectInspector>, int[]) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Returns true if the row does not pass through filters.
isFiltered(short, int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
isFinalMapRed() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
isFinished() - Method in class org.apache.hive.service.cli.operation.Operation
 
isFirst() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isFittingIntoMemory(Double, RelNode, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveAlgorithmsUtil
 
isFixedAsSorted() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isFixedPrecScale() - Method in enum org.apache.hive.service.cli.Type
Can this type represent money?
isFlat(RexCall) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ASTConverter
 
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
 
isForExplain() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
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
 
isFullSpec(Table, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
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
 
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
 
isGoOn() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
isGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
isGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
isGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
isGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
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.plan.RevokeDesc
 
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.HiveDecimalValueBoundaryScanner
 
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
 
isGreatest() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFGreatest
 
isGreatest() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeast
 
isGrouped() - Method in class org.apache.hadoop.hive.ql.exec.tez.MapRecordSource
 
isGrouped() - Method in interface org.apache.hadoop.hive.ql.exec.tez.RecordSource
 
isGrouped() - Method in class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource
 
isGroupingSetsPresent() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
isHadoop1() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
isHadoop23() - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
isHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
isHashMapOnDisk() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer.HashPartition
 
isHashMapSpilledOnCreation(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Check if the hash table of a specified partition has been "spilled" to disk when it was created.
isHasMapGroupBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isHasMoreRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
isHasResultSet() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
isHasUnknownPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
isHBaseGenerateHFiles(Configuration) - Static method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
Return true when HBaseStorageHandler should generate hfiles instead of operate against the online table.
isHbaseRowKey() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings.ColumnMapping
 
isHDFSCleanup() - Method in class org.apache.hadoop.hive.ql.Context
 
isHdfsEncryptionSupported() - Static method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
isHidden() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
isHiddenConfig(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
isHiddenVirtualCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
isHiveServerQuery() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
isHTTPTransportMode(HiveConf) - Static method in class org.apache.hive.service.server.HiveServer2
 
isHybridHashJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
isIdentifier() - Method in class org.apache.hive.service.cli.PatternOrIdentifier
 
isIdentitySelect() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
Checks whether this select operator does something to the input tuples.
isIfExists() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
isIfNotExists() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
isIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
isIgnoreProtection() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
isImmutable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isImmutableTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Determines whether a table is an immutable table.
isImpliesOrder() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isIncompatFile() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
isIndexTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isIndexTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isInfinite() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
isInit() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadDecimalResults
 
isInit() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveCharResults
 
isInit() - Method in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadHiveVarcharResults
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns true if the 'k' and 'pf' parameters have been set.
isInitialized() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
isInitialized() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
isInline(Vertex) - Static method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
isInputFormatSorted() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isInReplicationScope() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
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
 
isInsertIntoTable(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Check if a table is in the list to be inserted into
isInsertToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isInsertToTable() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isInternalTableFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Internal table functions cannot be used in the language.
isIntervalDayTimeFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isIntervalYearMonthFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isIntFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isIntToTimestampInSeconds() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTimestamp
 
isIsTblLevel() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
isJDODataStoreException(Exception) - Static method in class org.apache.hadoop.hive.ql.metadata.CheckJDOException
 
isJoinToken(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
Tests whether the parse tree node is a join token.
isKey(ImmutableBitSet) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
isLast() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
isLastColumnTakesRest() - Method in interface org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParameters
 
isLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
isLastDayOfMonth(Calendar) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAddMonths
 
isLastStripeInFile() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
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.calcite.cost.HiveCost
 
isLeftInputJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isLeftInputJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isLeftSemiJoin() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
isLinkedFileSink() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
isList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
isListBucketingAlterTableConcatenate - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
isListBucketingAlterTableConcatenate() - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
isListBucketingAlterTableConcatenate() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
isListBucketingAlterTableConcatenate() - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
isListBucketingPart(Partition) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
check if the partition is list bucketing
isLoadHiveServer2Config() - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
isLoadMetastoreConfig() - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
isLocal() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
isLocalFile(HiveConf, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
A best effort attempt to determine if if the file is a local file
isLocalFile(HiveConf, URI) - Static method in class org.apache.hadoop.hive.common.FileUtils
A best effort attempt to determine if if the file is a local file
isLocalMode() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isLocalMode(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
isLocalMode(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
isLocalMode(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Check wether MR is configured to run in local-mode
isLocalMode(Configuration) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
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
isLogDebugEnabled - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
isLogical() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isLogInfoEnabled - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
isLogInfoEnabled - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
isLogTraceEnabled - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
isLogTraceEnabled - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
isLt(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
isMajorCompaction() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
isMap - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
isMap() - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
Returns whether the UDF is called from Map or Reduce task.
isMap() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunction
 
isMap() - Method in class org.apache.hadoop.hive.ql.exec.spark.HivePairFlatMapFunction
 
isMap() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunction
 
isMap - Variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
isMap() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
isMap() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
isMap - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Are we writing a map and need to worry about k/v separator?
isMapEncoding(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
 
isMapGroupBy - Variable in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
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.spark.SparkTask
 
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
 
isMapSideJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isMapSideJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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
isMetadataOnly() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
isMetaStoreRemote() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
isMRShuffle() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
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
 
isMy_bool() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
isNative() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Native functions cannot be unregistered.
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
 
isNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
isNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
isNestedScript(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.DerbyCommandParser
 
isNestedScript(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MSSQLCommandParser
 
isNestedScript(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
isNestedScript(String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Find if the given command is a nested script execution
isNestedScript(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.OracleCommandParser
 
isNestedScript(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
isNewFormat() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
isNil() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
isNonExecCommand(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
isNonExecCommand(String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Find if the given command should not be passed to DB
isNonExecCommand(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
isNonNativeTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isNonVectorizedPathUDF(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isNoop() - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
isNoopFunction(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
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
 
isNoScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isNotEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
isNotEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
isNotEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
isNotEqual(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
isNotEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
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.
isNull(Text, ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
isNull(Text, byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
isNull - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
isNullable(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isNullableType(Schema) - Static method in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Determine if an Avro schema is of type Union[T, NULL].
isNullOperator(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
Throws an exception if the input operator is null
isNumericType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Check if the given type is numeric.
isNumericType() - Method in enum org.apache.hive.service.cli.Type
 
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isolation(String) - Method in class org.apache.hive.beeline.Commands
 
isOnDisk(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Check if the hash table of a specified partition is on disk (or "spilled" on creation)
isOne() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.abort_txn
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_dynamic_partitions
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_index
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_pspec
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_req
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_database
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_function
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_index
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partitions
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_cascade
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.cancel_delegation_token
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.check_lock
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.commit_txn
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.compact
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_database
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_function
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_type
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_partition_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_table_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_database
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_function
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_index_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partitions_req
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_type
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.exchange_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.fire_listener_event
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_aggr_stats_for
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_databases
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_tables
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_config_value
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_current_notificationEventId
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_database
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_databases
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_delegation_token
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_function
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_functions
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_names
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_indexes
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_next_notification
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns_info
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_part_specs_by_filter
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names_ps
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_with_auth
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_expr
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_filter
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_names
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps_with_auth
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_pspec
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_statistics_req
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_with_auth
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_principals_in_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_privilege_set
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_grants_for_principal
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_names
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema_with_environment_context
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_names_by_filter
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_objects_by_name
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_statistics_req
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_tables
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type_all
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.getMetaConf
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_privileges
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_privileges
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat_txn_range
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.isPartitionMarkedForEvent
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_privileges
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_roles
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.lock
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.markPartitionForEvent
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.open_txns
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_has_valid_characters
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_spec
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_vals
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.rename_partition
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.renew_delegation_token
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_privileges
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_role
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_aggr_stats_for
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_ugi
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.setMetaConf
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_compact
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_locks
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.unlock
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_partition_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_table_column_statistics
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.clean
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.execute
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchAll
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchN
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchOne
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getClusterStatus
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getQueryPlan
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getSchema
 
isOneway() - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor.getThriftSchema
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelDelegationToken
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelOperation
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseOperation
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseSession
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.ExecuteStatement
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.FetchResults
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetCatalogs
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetColumns
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetDelegationToken
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetFunctions
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetInfo
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetOperationStatus
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetResultSetMetadata
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetSchemas
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTables
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTableTypes
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTypeInfo
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.OpenSession
 
isOneway() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Processor.RenewDelegationToken
 
isOnlyForTesting() - Method in enum org.apache.hadoop.hive.ql.processors.HiveCommand
 
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".
isOpCast(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is node of "cast".
isOpCast(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
isOpen() - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
 
isOpen() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
isOpen() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Returns whether a session has been established
isOpen() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
isOperationLogEnabled - Variable in class org.apache.hive.service.cli.operation.Operation
 
isOperationLogEnabled() - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Check whether operation logging is enabled and session dir is created successfully
isOperationLogEnabled() - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
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
isOptional() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Chain
 
isOptional() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Plus
 
isOptional() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Star
 
isOptional() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Symbol
 
isOptional() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunction
 
isOrdering() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isOriginal(Reader) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
isOriginal() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
isOriginal() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
isOuterJoin - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
isOuterJoin() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinTypeCheckCtx
 
isOuterLateralView() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
isOuterLV() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
isOwnerOfFileHierarchy(FileSystem, FileStatus, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
isPartialCommand(String) - Method in class org.apache.hive.beeline.HiveSchemaHelper.MySqlCommandParser
 
isPartialCommand(String) - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Find the type of given command
isPartialScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isPartialScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
isPartialScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isPartition() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Returns true in case this data container is a partition.
isPartitionCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Determine whether a given column is a partition column
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
 
isPartitioning() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isPartitionKey(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hive.hcatalog.api.HCatClient
Checks if a partition is marked for event.
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
isPathEncrypted(Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.HdfsEncryptionShim
 
isPathEncrypted(Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.HdfsEncryptionShim
Checks if a given HDFS path is encrypted.
isPathEncrypted(Path) - Method in class org.apache.hadoop.hive.shims.HadoopShims.NoopHdfsEncryptionShim
 
isPathType() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
isPattern() - Method in class org.apache.hive.service.cli.PatternOrIdentifier
 
isPerfOrAboveLogging(HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Checks if the current HiveServer2 logging operation level is >= PERFORMANCE.
isPersistent() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isPhaseTransition(HiveJoin) - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
isPhaseTransition() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
isPhaseTransition(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
isPhaseTransition(HiveSort) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
isPivotResult() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isPivotResult() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
isPoolable() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
isPoolable() - Method in class org.apache.hive.jdbc.HiveStatement
 
isPositive - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
isPositive - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
isPositive - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
isPositive() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
isPrefix(String) - Static method in class org.apache.hadoop.hive.accumulo.columns.ColumnMappingFactory
 
isPrefixedBy(PTFInvocationSpec.PartitionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
isPretty() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isPrimaryKey() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
isPrimitive() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
isPrimitive() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
isPrimitive() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
isPrimitive() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
isPrimitive() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
isPrimitiveJava(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Whether the class is a Java Primitive type or a Java Primitive class.
isPrimitiveJavaClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Whether the class is a Java Primitive class.
isPrimitiveJavaType(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Whether the class is a Java Primitive type.
isPrimitiveType() - Method in enum org.apache.hive.service.cli.Type
 
isPrimitiveWritableClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Whether the class is a Hive Primitive Writable class.
isProtectModeEnable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
isPTFReduceSink() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isQualifiedFunctionName(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
isQualifiedType() - Method in enum org.apache.hive.service.cli.Type
 
isQuery() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isQueryHasGroupBy() - 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
isReadAllColumns(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Returns the READ_ALL_COLUMNS columns flag.
isReadOnly() - Method in class org.apache.hive.jdbc.HiveConnection
 
isReadOnly() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
isReadOnly(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isReady(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
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().
isRealThrift - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
Indicates whether fields can be out of order or missing.
isReduce() - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
isRedundantConversionFunction(ASTNode, boolean, ArrayList<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
isRegisteredWithZooKeeper() - Method in class org.apache.hive.service.server.HiveServer2
 
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
 
isRetriable() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
isRetriable() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
isRetriable() - Method in enum org.apache.hive.hcatalog.common.ErrorType
Checks if this is a retriable error.
isRetriable() - Method in exception org.apache.hive.hcatalog.common.HCatException
Is this a retriable error.
isReverseOrder - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
isRevokeGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
isRootTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isRunAsync() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
isRunFromMetaStore() - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
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
 
isRunning() - Method in class org.apache.hive.service.cli.operation.Operation
 
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.ExprNodeDynamicListDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
isSameColumnForRR(ColumnInfo) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
isSameTypeOrFamily(VectorExpressionDescriptor.ArgumentType) - Method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
isSearchable(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
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
 
isSet(AbortTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AddDynamicPartitions._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AddPartitionsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AddPartitionsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AggrStats._Fields) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BinaryColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BooleanColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CheckLockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ColumnStatistics._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ColumnStatisticsDesc._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ColumnStatisticsObj._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CommitTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ConfigValSecurityException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CurrentNotificationEventId._Fields) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Database._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Date._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Date
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DateColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Decimal._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecimalColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DoubleColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DropPartitionsExpr._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DropPartitionsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DropPartitionsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(EnvironmentContext._Fields) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FieldSchema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FireEventRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FireEventResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Function._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetOpenTxnsInfoResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetOpenTxnsResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPrincipalsInRoleRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPrincipalsInRoleResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetRoleGrantsForPrincipalRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetRoleGrantsForPrincipalResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GrantRevokePrivilegeRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GrantRevokePrivilegeResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GrantRevokeRoleRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GrantRevokeRoleResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HeartbeatRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HeartbeatTxnRangeRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HeartbeatTxnRangeResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HiveObjectPrivilege._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HiveObjectRef._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Index._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IndexAlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InsertEventRequestData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InvalidInputException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InvalidObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InvalidOperationException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InvalidPartitionException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LockComponent._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LockResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LongColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NoSuchLockException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NoSuchObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NoSuchTxnException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NotificationEvent._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NotificationEventRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NotificationEventResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(OpenTxnRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(OpenTxnsResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Order._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Partition._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionListComposingSpec._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionsByExprRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionsByExprResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionSpec._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionSpecWithSharedSD._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionsStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionsStatsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionWithoutSD._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PrincipalPrivilegeSet._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PrivilegeBag._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PrivilegeGrantInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ResourceUri._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Role._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RolePrincipalGrant._Fields) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Schema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SerDeInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SetPartitionsStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowCompactRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowCompactResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowCompactResponseElement._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowLocksRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowLocksResponse._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ShowLocksResponseElement._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SkewedInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StorageDescriptor._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StringColumnStatsData._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Table._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TableStatsRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TableStatsResult._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.abort_txn_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.abort_txn_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_dynamic_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_dynamic_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_pspec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_pspec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_with_cascade_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_with_cascade_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.cancel_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.cancel_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.check_lock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.check_lock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.commit_txn_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.commit_txn_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.compact_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.compact_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.delete_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.delete_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.delete_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.delete_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partitions_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partitions_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.exchange_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.exchange_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.fire_listener_event_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.fire_listener_event_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_aggr_stats_for_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_aggr_stats_for_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_config_value_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_config_value_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_current_notificationEventId_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_current_notificationEventId_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_function_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_function_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_functions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_functions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_indexes_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_indexes_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_next_notification_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_next_notification_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_open_txns_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_open_txns_info_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_open_txns_info_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_open_txns_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_part_specs_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_part_specs_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_expr_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_expr_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_pspec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_pspec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_statistics_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_statistics_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_principals_in_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_principals_in_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_privilege_set_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_privilege_set_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_grants_for_principal_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_grants_for_principal_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_with_environment_context_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_with_environment_context_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_names_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_names_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_objects_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_objects_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_statistics_req_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_statistics_req_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_all_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_all_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.getMetaConf_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.getMetaConf_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.heartbeat_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.heartbeat_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.heartbeat_txn_range_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.heartbeat_txn_range_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_roles_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_roles_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.lock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.lock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.markPartitionForEvent_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.markPartitionForEvent_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.open_txns_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.open_txns_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_spec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_spec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_vals_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_vals_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.rename_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.rename_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.renew_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.renew_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.set_aggr_stats_for_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.set_aggr_stats_for_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.set_ugi_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.set_ugi_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.setMetaConf_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.setMetaConf_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.show_compact_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.show_compact_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.show_locks_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.show_locks_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.unlock_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.unlock_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.update_partition_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.update_partition_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.update_table_column_statistics_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHiveMetastore.update_table_column_statistics_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TxnAbortedException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TxnInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TxnOpenException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Type._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnknownDBException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnknownPartitionException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnknownTableException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnlockRequest._Fields) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Version._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Adjacency._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Graph._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Operator._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Query._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(QueryPlan._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Stage._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Task._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InnerStruct._Fields) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTestObj._Fields) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Complex._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MegaStruct._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MiniStruct._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SetIntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HiveClusterStatus._Fields) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HiveServerException._Fields) - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.clean_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.clean_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.execute_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.execute_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchAll_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchAll_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchN_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchN_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchOne_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.fetchOne_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getClusterStatus_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getClusterStatus_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getQueryPlan_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getQueryPlan_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getThriftSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftHive.getThriftSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isset() - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Is the object non-empty?
isset(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Is the object non-empty?
isset(char) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Is the object non-empty?
isset(T[]) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Is the object non-empty?
isset(Collection<T>) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Is the object non-empty?
isset(Map<K, V>) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Is the object non-empty?
isSet(TArrayTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TBinaryColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TBoolColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TBoolValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TByteColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TByteValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TByteValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCancelDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCancelDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCancelOperationReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCancelOperationResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CancelDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CancelDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CancelOperation_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CancelOperation_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CloseOperation_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CloseOperation_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CloseSession_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.CloseSession_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.ExecuteStatement_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.ExecuteStatement_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.FetchResults_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.FetchResults_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetCatalogs_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetCatalogs_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetColumns_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetColumns_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetFunctions_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetFunctions_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetInfo_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetInfo_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetOperationStatus_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetOperationStatus_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetResultSetMetadata_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetResultSetMetadata_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetSchemas_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetSchemas_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTables_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTables_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTableTypes_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTableTypes_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTypeInfo_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.GetTypeInfo_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.OpenSession_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.OpenSession_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.RenewDelegationToken_args._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCLIService.RenewDelegationToken_result._Fields) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCloseOperationReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCloseOperationResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCloseSessionReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCloseSessionResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumnDesc._Fields) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TDoubleColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TDoubleValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TExecuteStatementReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TExecuteStatementResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TFetchResultsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TFetchResultsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetCatalogsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetCatalogsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetColumnsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetColumnsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetFunctionsReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetFunctionsResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetInfoReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetInfoResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetOperationStatusReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetOperationStatusResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetResultSetMetadataReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetResultSetMetadataResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetSchemasReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetSchemasResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTablesReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTablesResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTableTypesReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTableTypesResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTypeInfoReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGetTypeInfoResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THandleIdentifier._Fields) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI16Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI16Column
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI16Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI16Value
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI32Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI32Column
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI32Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI32Value
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI64Column._Fields) - Method in class org.apache.hive.service.cli.thrift.TI64Column
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TI64Value._Fields) - Method in class org.apache.hive.service.cli.thrift.TI64Value
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TMapTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TOpenSessionReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TOpenSessionResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TOperationHandle._Fields) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TPrimitiveTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRenewDelegationTokenReq._Fields) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRenewDelegationTokenResp._Fields) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRow._Fields) - Method in class org.apache.hive.service.cli.thrift.TRow
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRowSet._Fields) - Method in class org.apache.hive.service.cli.thrift.TRowSet
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TSessionHandle._Fields) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TStatus._Fields) - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TStringColumn._Fields) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TStringValue._Fields) - Method in class org.apache.hive.service.cli.thrift.TStringValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TStructTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTableSchema._Fields) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTypeDesc._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTypeQualifiers._Fields) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TUnionTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TUserDefinedTypeEntry._Fields) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetAborted() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
Returns true if field aborted is set (has been assigned a value) and false otherwise
isSetAcquiredat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field acquiredat is set (has been assigned a value) and false otherwise
isSetAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field adjacencyList is set (has been assigned a value) and false otherwise
isSetAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field adjacencyType is set (has been assigned a value) and false otherwise
isSetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field aint is set (has been assigned a value) and false otherwise
isSetArrayEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field aString is set (has been assigned a value) and false otherwise
isSetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
Returns true if field aString is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
Returns true if field avgColLen is set (has been assigned a value) and false otherwise
isSetAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Returns true if field avgColLen is set (has been assigned a value) and false otherwise
isSetBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field base_tbl_name is set (has been assigned a value) and false otherwise
isSetBinaryStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetBinaryVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetBinaryValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetBooleanStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetBoolVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetBoolVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field bucketCols is set (has been assigned a value) and false otherwise
isSetByteVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetByteVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Returns true if field cascade is set (has been assigned a value) and false otherwise
isSetCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field cascade is set (has been assigned a value) and false otherwise
isSetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field catalogName is set (has been assigned a value) and false otherwise
isSetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Returns true if field catalogName is set (has been assigned a value) and false otherwise
isSetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
Returns true if field catalogName is set (has been assigned a value) and false otherwise
isSetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field catalogName is set (has been assigned a value) and false otherwise
isSetChildren() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field children is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field className is set (has been assigned a value) and false otherwise
isSetClient_protocol() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
Returns true if field client_protocol is set (has been assigned a value) and false otherwise
isSetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field col is set (has been assigned a value) and false otherwise
isSetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Returns true if field col_name is set (has been assigned a value) and false otherwise
isSetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
Returns true if field col_name is set (has been assigned a value) and false otherwise
isSetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Returns true if field col_name is set (has been assigned a value) and false otherwise
isSetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
Returns true if field col_name is set (has been assigned a value) and false otherwise
isSetColName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
Returns true if field colName is set (has been assigned a value) and false otherwise
isSetColNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Returns true if field colNames is set (has been assigned a value) and false otherwise
isSetColNames() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
Returns true if field colNames is set (has been assigned a value) and false otherwise
isSetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field cols is set (has been assigned a value) and false otherwise
isSetColStats() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
Returns true if field colStats is set (has been assigned a value) and false otherwise
isSetColStats() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
Returns true if field colStats is set (has been assigned a value) and false otherwise
isSetColType() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
Returns true if field colType is set (has been assigned a value) and false otherwise
isSetColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field columnName is set (has been assigned a value) and false otherwise
isSetColumnName() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
Returns true if field columnName is set (has been assigned a value) and false otherwise
isSetColumnName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field columnName is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hive.service.cli.thrift.TRowSet
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColVals() - Method in class org.apache.hive.service.cli.thrift.TRow
Returns true if field colVals is set (has been assigned a value) and false otherwise
isSetComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field comment is set (has been assigned a value) and false otherwise
isSetComment() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
Returns true if field comment is set (has been assigned a value) and false otherwise
isSetComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field comments is set (has been assigned a value) and false otherwise
isSetCompacts() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
Returns true if field compacts is set (has been assigned a value) and false otherwise
isSetComponent() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
Returns true if field component is set (has been assigned a value) and false otherwise
isSetCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field compressed is set (has been assigned a value) and false otherwise
isSetConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
Returns true if field configuration is set (has been assigned a value) and false otherwise
isSetConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
Returns true if field configuration is set (has been assigned a value) and false otherwise
isSetConfOverlay() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Returns true if field confOverlay is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field createTime is set (has been assigned a value) and false otherwise
isSetData() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field data is set (has been assigned a value) and false otherwise
isSetDatabase() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Returns true if field database is set (has been assigned a value) and false otherwise
isSetDateStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetDaysSinceEpoch() - Method in class org.apache.hadoop.hive.metastore.api.Date
Returns true if field daysSinceEpoch is set (has been assigned a value) and false otherwise
isSetDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field db is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Returns true if field db_name is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
Returns true if field dbName is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
Returns true if field dbname is set (has been assigned a value) and false otherwise
isSetDecimalStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetDefaultPartitionName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field defaultPartitionName is set (has been assigned a value) and false otherwise
isSetDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field defaultValue is set (has been assigned a value) and false otherwise
isSetDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field deferredRebuild is set (has been assigned a value) and false otherwise
isSetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
Returns true if field delegationToken is set (has been assigned a value) and false otherwise
isSetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
Returns true if field delegationToken is set (has been assigned a value) and false otherwise
isSetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
Returns true if field delegationToken is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Returns true if field deleteData is set (has been assigned a value) and false otherwise
isSetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDest_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field dest_db is set (has been assigned a value) and false otherwise
isSetDest_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field dest_table_name is set (has been assigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field done is set (has been assigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field done is set (has been assigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field done is set (has been assigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field done is set (has been assigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field done is set (has been assigned a value) and false otherwise
isSetDoubleStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetDoubleVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetDoubleVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetDoubleValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
Returns true if field environment_context is set (has been assigned a value) and false otherwise
isSetEnvironmentContext() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field environmentContext is set (has been assigned a value) and false otherwise
isSetErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field errorCode is set (has been assigned a value) and false otherwise
isSetErrorCode() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field errorCode is set (has been assigned a value) and false otherwise
isSetErrorCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field errorCode is set (has been assigned a value) and false otherwise
isSetErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field errorMessage is set (has been assigned a value) and false otherwise
isSetErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field errorMessage is set (has been assigned a value) and false otherwise
isSetEventId() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
Returns true if field eventId is set (has been assigned a value) and false otherwise
isSetEventId() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field eventId is set (has been assigned a value) and false otherwise
isSetEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
Returns true if field events is set (has been assigned a value) and false otherwise
isSetEventTime() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field eventTime is set (has been assigned a value) and false otherwise
isSetEventType() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field eventType is set (has been assigned a value) and false otherwise
isSetEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Returns true if field eventType is set (has been assigned a value) and false otherwise
isSetEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Returns true if field eventType is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetExpr() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
Returns true if field expr is set (has been assigned a value) and false otherwise
isSetExpr() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field expr is set (has been assigned a value) and false otherwise
isSetExprs() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
isSetFetchType() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
Returns true if field fetchType is set (has been assigned a value) and false otherwise
isSetField0() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
Returns true if field field0 is set (has been assigned a value) and false otherwise
isSetField1() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field1 is set (has been assigned a value) and false otherwise
isSetField2() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field2 is set (has been assigned a value) and false otherwise
isSetField3() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field3 is set (has been assigned a value) and false otherwise
isSetFields() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field fields is set (has been assigned a value) and false otherwise
isSetFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field fieldSchemas is set (has been assigned a value) and false otherwise
isSetFilesAdded() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
Returns true if field filesAdded is set (has been assigned a value) and false otherwise
isSetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Returns true if field filter is set (has been assigned a value) and false otherwise
isSetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field filter is set (has been assigned a value) and false otherwise
isSetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
Returns true if field filter is set (has been assigned a value) and false otherwise
isSetFlag() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
Returns true if field func is set (has been assigned a value) and false otherwise
isSetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
Returns true if field funcName is set (has been assigned a value) and false otherwise
isSetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
Returns true if field funcName is set (has been assigned a value) and false otherwise
isSetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
Returns true if field funcName is set (has been assigned a value) and false otherwise
isSetFunctionName() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field functionName is set (has been assigned a value) and false otherwise
isSetFunctionName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Returns true if field functionName is set (has been assigned a value) and false otherwise
isSetFunctionType() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field functionType is set (has been assigned a value) and false otherwise
isSetGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grant_option is set (has been assigned a value) and false otherwise
isSetGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field grantInfo is set (has been assigned a value) and false otherwise
isSetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field grantOption is set (has been assigned a value) and false otherwise
isSetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantOption is set (has been assigned a value) and false otherwise
isSetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field grantOption is set (has been assigned a value) and false otherwise
isSetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field grantor is set (has been assigned a value) and false otherwise
isSetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantor is set (has been assigned a value) and false otherwise
isSetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grantor is set (has been assigned a value) and false otherwise
isSetGrantorName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field grantorName is set (has been assigned a value) and false otherwise
isSetGrantorPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field grantorPrincipalType is set (has been assigned a value) and false otherwise
isSetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field grantorType is set (has been assigned a value) and false otherwise
isSetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantorType is set (has been assigned a value) and false otherwise
isSetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grantorType is set (has been assigned a value) and false otherwise
isSetGrantTime() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field grantTime is set (has been assigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field group_names is set (has been assigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field group_names is set (has been assigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field group_names is set (has been assigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field group_names is set (has been assigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
Returns true if field group_names is set (has been assigned a value) and false otherwise
isSetGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field groupPrivileges is set (has been assigned a value) and false otherwise
isSetGuid() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
Returns true if field guid is set (has been assigned a value) and false otherwise
isSetHasMoreRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
Returns true if field hasMoreRows is set (has been assigned a value) and false otherwise
isSetHasResultSet() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
Returns true if field hasResultSet is set (has been assigned a value) and false otherwise
isSetHasUnknownPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
Returns true if field hasUnknownPartitions is set (has been assigned a value) and false otherwise
isSetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Returns true if field highValue is set (has been assigned a value) and false otherwise
isSetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Returns true if field highValue is set (has been assigned a value) and false otherwise
isSetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Returns true if field highValue is set (has been assigned a value) and false otherwise
isSetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Returns true if field highValue is set (has been assigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field hiveObject is set (has been assigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field hiveObject is set (has been assigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field hiveObject is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetI16Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetI16Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetI32Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetI32Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetI32Value() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
isSetI64Val() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetI64Val() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetId() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
Returns true if field id is set (has been assigned a value) and false otherwise
isSetIds() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
Returns true if field ids is set (has been assigned a value) and false otherwise
isSetIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field idx_name is set (has been assigned a value) and false otherwise
isSetIfExists() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field ifExists is set (has been assigned a value) and false otherwise
isSetIfNotExists() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field ifNotExists is set (has been assigned a value) and false otherwise
isSetIgnoreProtection() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field ignoreProtection is set (has been assigned a value) and false otherwise
isSetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field index_name is set (has been assigned a value) and false otherwise
isSetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field index_name is set (has been assigned a value) and false otherwise
isSetIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field index_table is set (has been assigned a value) and false otherwise
isSetIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexHandlerClass is set (has been assigned a value) and false otherwise
isSetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexName is set (has been assigned a value) and false otherwise
isSetIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexTableName is set (has been assigned a value) and false otherwise
isSetInfoMessages() - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field infoMessages is set (has been assigned a value) and false otherwise
isSetInfoType() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
Returns true if field infoType is set (has been assigned a value) and false otherwise
isSetInfoValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
Returns true if field infoValue is set (has been assigned a value) and false otherwise
isSetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field inputFormat is set (has been assigned a value) and false otherwise
isSetInsertData() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
isSetIntegerBitmask() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetIntegerFlag() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetIntValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetIsTblLevel() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field isTblLevel is set (has been assigned a value) and false otherwise
isSetKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
Returns true if field key is set (has been assigned a value) and false otherwise
isSetKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
Returns true if field key is set (has been assigned a value) and false otherwise
isSetKeyTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
Returns true if field keyTypePtr is set (has been assigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field lastAccessTime is set (has been assigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field lastAccessTime is set (has been assigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field lastAccessTime is set (has been assigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field lastAccessTime is set (has been assigned a value) and false otherwise
isSetLastAnalyzed() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field lastAnalyzed is set (has been assigned a value) and false otherwise
isSetLastEvent() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
Returns true if field lastEvent is set (has been assigned a value) and false otherwise
isSetLastheartbeat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field lastheartbeat is set (has been assigned a value) and false otherwise
isSetLenValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetLevel() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field level is set (has been assigned a value) and false otherwise
isSetLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lint is set (has been assigned a value) and false otherwise
isSetLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lintString is set (has been assigned a value) and false otherwise
isSetLocation() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field location is set (has been assigned a value) and false otherwise
isSetLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field locationUri is set (has been assigned a value) and false otherwise
isSetLockid() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
Returns true if field lockid is set (has been assigned a value) and false otherwise
isSetLockid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
Returns true if field lockid is set (has been assigned a value) and false otherwise
isSetLockid() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
Returns true if field lockid is set (has been assigned a value) and false otherwise
isSetLockid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field lockid is set (has been assigned a value) and false otherwise
isSetLockid() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
Returns true if field lockid is set (has been assigned a value) and false otherwise
isSetLocks() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
Returns true if field locks is set (has been assigned a value) and false otherwise
isSetLongStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetLongValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Returns true if field lowValue is set (has been assigned a value) and false otherwise
isSetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Returns true if field lowValue is set (has been assigned a value) and false otherwise
isSetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Returns true if field lowValue is set (has been assigned a value) and false otherwise
isSetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Returns true if field lowValue is set (has been assigned a value) and false otherwise
isSetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lString is set (has been assigned a value) and false otherwise
isSetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetMapEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field mapTasks is set (has been assigned a value) and false otherwise
isSetMax() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
Returns true if field max is set (has been assigned a value) and false otherwise
isSetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field max_indexes is set (has been assigned a value) and false otherwise
isSetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field max_indexes is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field max_parts is set (has been assigned a value) and false otherwise
isSetMax_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
Returns true if field max_tables is set (has been assigned a value) and false otherwise
isSetMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
Returns true if field maxColLen is set (has been assigned a value) and false otherwise
isSetMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Returns true if field maxColLen is set (has been assigned a value) and false otherwise
isSetMaxEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
Returns true if field maxEvents is set (has been assigned a value) and false otherwise
isSetMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field maxMapTasks is set (has been assigned a value) and false otherwise
isSetMaxParts() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field maxParts is set (has been assigned a value) and false otherwise
isSetMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field maxReduceTasks is set (has been assigned a value) and false otherwise
isSetMaxRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
Returns true if field maxRows is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMin() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
Returns true if field min is set (has been assigned a value) and false otherwise
isSetModifiedRowCount() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
Returns true if field modifiedRowCount is set (has been assigned a value) and false otherwise
isSetMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field mStringString is set (has been assigned a value) and false otherwise
isSetMy_16bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_16bit_int is set (has been assigned a value) and false otherwise
isSetMy_32bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_32bit_int is set (has been assigned a value) and false otherwise
isSetMy_64bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_64bit_int is set (has been assigned a value) and false otherwise
isSetMy_binary() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_binary is set (has been assigned a value) and false otherwise
isSetMy_bool() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_bool is set (has been assigned a value) and false otherwise
isSetMy_byte() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_byte is set (has been assigned a value) and false otherwise
isSetMy_double() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_double is set (has been assigned a value) and false otherwise
isSetMy_enum() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
Returns true if field my_enum is set (has been assigned a value) and false otherwise
isSetMy_enum_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enum_string_map is set (has been assigned a value) and false otherwise
isSetMy_enum_stringlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enum_stringlist_map is set (has been assigned a value) and false otherwise
isSetMy_enum_struct_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enum_struct_map is set (has been assigned a value) and false otherwise
isSetMy_enum_structlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enum_structlist_map is set (has been assigned a value) and false otherwise
isSetMy_enumlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enumlist is set (has been assigned a value) and false otherwise
isSetMy_enumset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_enumset is set (has been assigned a value) and false otherwise
isSetMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_string is set (has been assigned a value) and false otherwise
isSetMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
Returns true if field my_string is set (has been assigned a value) and false otherwise
isSetMy_string_enum_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_string_enum_map is set (has been assigned a value) and false otherwise
isSetMy_string_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_string_string_map is set (has been assigned a value) and false otherwise
isSetMy_stringlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_stringlist is set (has been assigned a value) and false otherwise
isSetMy_stringset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_stringset is set (has been assigned a value) and false otherwise
isSetMy_structlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_structlist is set (has been assigned a value) and false otherwise
isSetMy_structset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Returns true if field my_structset is set (has been assigned a value) and false otherwise
isSetMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field myint is set (has been assigned a value) and false otherwise
isSetMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field myString is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field name is set (has been assigned a value) and false otherwise
isSetNames() - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
isSetNames() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
Returns true if field names is set (has been assigned a value) and false otherwise
isSetNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
Returns true if field nameToTypePtr is set (has been assigned a value) and false otherwise
isSetNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
Returns true if field nameToTypePtr is set (has been assigned a value) and false otherwise
isSetNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field needResult is set (has been assigned a value) and false otherwise
isSetNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field needResult is set (has been assigned a value) and false otherwise
isSetNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field new_idx is set (has been assigned a value) and false otherwise
isSetNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field new_index is set (has been assigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Returns true if field new_part is set (has been assigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
Returns true if field new_part is set (has been assigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field new_part is set (has been assigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Returns true if field new_part is set (has been assigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Returns true if field new_part is set (has been assigned a value) and false otherwise
isSetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
Returns true if field new_parts is set (has been assigned a value) and false otherwise
isSetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
Returns true if field new_parts is set (has been assigned a value) and false otherwise
isSetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
Returns true if field new_parts is set (has been assigned a value) and false otherwise
isSetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field new_tbl is set (has been assigned a value) and false otherwise
isSetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Returns true if field new_tbl is set (has been assigned a value) and false otherwise
isSetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Returns true if field new_tbl is set (has been assigned a value) and false otherwise
isSetNewFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
Returns true if field newFunc is set (has been assigned a value) and false otherwise
isSetNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field node is set (has been assigned a value) and false otherwise
isSetNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field nodeType is set (has been assigned a value) and false otherwise
isSetNosuch() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
Returns true if field nosuch is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TI16Column
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TI32Column
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TI64Column
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNulls() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
Returns true if field nulls is set (has been assigned a value) and false otherwise
isSetNum_txns() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
Returns true if field num_txns is set (has been assigned a value) and false otherwise
isSetNumBuckets() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field numBuckets is set (has been assigned a value) and false otherwise
isSetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Returns true if field numDVs is set (has been assigned a value) and false otherwise
isSetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Returns true if field numDVs is set (has been assigned a value) and false otherwise
isSetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Returns true if field numDVs is set (has been assigned a value) and false otherwise
isSetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Returns true if field numDVs is set (has been assigned a value) and false otherwise
isSetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Returns true if field numDVs is set (has been assigned a value) and false otherwise
isSetNumFalses() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
Returns true if field numFalses is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Returns true if field numNulls is set (has been assigned a value) and false otherwise
isSetNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Returns true if field numRows is set (has been assigned a value) and false otherwise
isSetNumTrues() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
Returns true if field numTrues is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field o1 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field o2 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field o3 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field o4 is set (has been assigned a value) and false otherwise
isSetO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o5 is set (has been assigned a value) and false otherwise
isSetO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o5 is set (has been assigned a value) and false otherwise
isSetO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field o6 is set (has been assigned a value) and false otherwise
isSetO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Returns true if field o6 is set (has been assigned a value) and false otherwise
isSetObjectName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field objectName is set (has been assigned a value) and false otherwise
isSetObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field objectType is set (has been assigned a value) and false otherwise
isSetObjectTypePtr() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
Returns true if field objectTypePtr is set (has been assigned a value) and false otherwise
isSetOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
Returns true if field open_txns is set (has been assigned a value) and false otherwise
isSetOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
Returns true if field open_txns is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
Returns true if field operationHandle is set (has been assigned a value) and false otherwise
isSetOperationId() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
Returns true if field operationId is set (has been assigned a value) and false otherwise
isSetOperationState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field operationState is set (has been assigned a value) and false otherwise
isSetOperationType() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
Returns true if field operationType is set (has been assigned a value) and false otherwise
isSetOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorAttributes is set (has been assigned a value) and false otherwise
isSetOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorCounters is set (has been assigned a value) and false otherwise
isSetOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field operatorGraph is set (has been assigned a value) and false otherwise
isSetOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorId is set (has been assigned a value) and false otherwise
isSetOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field operatorList is set (has been assigned a value) and false otherwise
isSetOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorType is set (has been assigned a value) and false otherwise
isSetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field order is set (has been assigned a value) and false otherwise
isSetOrientation() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
Returns true if field orientation is set (has been assigned a value) and false otherwise
isSetOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field origTableName is set (has been assigned a value) and false otherwise
isSetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field outputFormat is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field ownerName is set (has been assigned a value) and false otherwise
isSetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field ownerName is set (has been assigned a value) and false otherwise
isSetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field ownerName is set (has been assigned a value) and false otherwise
isSetOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field ownerType is set (has been assigned a value) and false otherwise
isSetOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field ownerType is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field parameters is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Returns true if field part_name is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Returns true if field part_vals is set (has been assigned a value) and false otherwise
isSetPartArchiveLevel() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
Returns true if field partArchiveLevel is set (has been assigned a value) and false otherwise
isSetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field partitionKeys is set (has been assigned a value) and false otherwise
isSetPartitionList() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field partitionList is set (has been assigned a value) and false otherwise
isSetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field partitionname is set (has been assigned a value) and false otherwise
isSetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field partitionname is set (has been assigned a value) and false otherwise
isSetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field partitionname is set (has been assigned a value) and false otherwise
isSetPartitionnames() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Returns true if field partitionnames is set (has been assigned a value) and false otherwise
isSetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
Returns true if field partitions is set (has been assigned a value) and false otherwise
isSetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
Returns true if field partitions is set (has been assigned a value) and false otherwise
isSetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
Returns true if field partitions is set (has been assigned a value) and false otherwise
isSetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
Returns true if field partitions is set (has been assigned a value) and false otherwise
isSetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
Returns true if field partitions is set (has been assigned a value) and false otherwise
isSetPartitionSpecs() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field partitionSpecs is set (has been assigned a value) and false otherwise
isSetPartitionVals() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field partitionVals is set (has been assigned a value) and false otherwise
isSetPartName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field partName is set (has been assigned a value) and false otherwise
isSetPartname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field partname is set (has been assigned a value) and false otherwise
isSetPartNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Returns true if field partNames is set (has been assigned a value) and false otherwise
isSetParts() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field parts is set (has been assigned a value) and false otherwise
isSetParts() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field parts is set (has been assigned a value) and false otherwise
isSetPartsFound() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
Returns true if field partsFound is set (has been assigned a value) and false otherwise
isSetPartStats() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
Returns true if field partStats is set (has been assigned a value) and false otherwise
isSetPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field partValues is set (has been assigned a value) and false otherwise
isSetPassword() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
Returns true if field password is set (has been assigned a value) and false otherwise
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Returns true if field pattern is set (has been assigned a value) and false otherwise
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
Returns true if field pattern is set (has been assigned a value) and false otherwise
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field pattern is set (has been assigned a value) and false otherwise
isSetPosition() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
Returns true if field position is set (has been assigned a value) and false otherwise
isSetPrimitiveEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
Returns true if field principal_name is set (has been assigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field principal_name is set (has been assigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field principal_name is set (has been assigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field principal_name is set (has been assigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field principal_name is set (has been assigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
Returns true if field principal_type is set (has been assigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field principal_type is set (has been assigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field principal_type is set (has been assigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field principal_type is set (has been assigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field principal_type is set (has been assigned a value) and false otherwise
isSetPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
Returns true if field principalGrants is set (has been assigned a value) and false otherwise
isSetPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
Returns true if field principalGrants is set (has been assigned a value) and false otherwise
isSetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field principalName is set (has been assigned a value) and false otherwise
isSetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field principalName is set (has been assigned a value) and false otherwise
isSetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field principalName is set (has been assigned a value) and false otherwise
isSetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field principalType is set (has been assigned a value) and false otherwise
isSetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field principalType is set (has been assigned a value) and false otherwise
isSetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field principalType is set (has been assigned a value) and false otherwise
isSetPrivilege() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field privilege is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Returns true if field privileges is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetQualifiers() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
Returns true if field qualifiers is set (has been assigned a value) and false otherwise
isSetQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field queries is set (has been assigned a value) and false otherwise
isSetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
Returns true if field query is set (has been assigned a value) and false otherwise
isSetQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryAttributes is set (has been assigned a value) and false otherwise
isSetQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryCounters is set (has been assigned a value) and false otherwise
isSetQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryId is set (has been assigned a value) and false otherwise
isSetQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryType is set (has been assigned a value) and false otherwise
isSetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field reduceTasks is set (has been assigned a value) and false otherwise
isSetRelativePath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field relativePath is set (has been assigned a value) and false otherwise
isSetRenewer() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
Returns true if field renewer is set (has been assigned a value) and false otherwise
isSetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Returns true if field renewer_kerberos_principal_name is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
Returns true if field req is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
Returns true if field requestType is set (has been assigned a value) and false otherwise
isSetRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field requestType is set (has been assigned a value) and false otherwise
isSetResourceType() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
Returns true if field resourceType is set (has been assigned a value) and false otherwise
isSetResourceUris() - Method in class org.apache.hadoop.hive.metastore.api.Function
Returns true if field resourceUris is set (has been assigned a value) and false otherwise
isSetResults() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
Returns true if field results is set (has been assigned a value) and false otherwise
isSetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field retention is set (has been assigned a value) and false otherwise
isSetRevokeGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
Returns true if field revokeGrantOption is set (has been assigned a value) and false otherwise
isSetRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Returns true if field role is set (has been assigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Returns true if field role_name is set (has been assigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field role_name is set (has been assigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field role_name is set (has been assigned a value) and false otherwise
isSetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
Returns true if field roleName is set (has been assigned a value) and false otherwise
isSetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
Returns true if field roleName is set (has been assigned a value) and false otherwise
isSetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field roleName is set (has been assigned a value) and false otherwise
isSetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Returns true if field roleName is set (has been assigned a value) and false otherwise
isSetRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field rolePrivileges is set (has been assigned a value) and false otherwise
isSetRootPath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field rootPath is set (has been assigned a value) and false otherwise
isSetRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field roots is set (has been assigned a value) and false otherwise
isSetRows() - Method in class org.apache.hive.service.cli.thrift.TRowSet
Returns true if field rows is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
Returns true if field rqst is set (has been assigned a value) and false otherwise
isSetRunas() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field runas is set (has been assigned a value) and false otherwise
isSetRunAs() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field runAs is set (has been assigned a value) and false otherwise
isSetRunAsync() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Returns true if field runAsync is set (has been assigned a value) and false otherwise
isSetScale() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
Returns true if field scale is set (has been assigned a value) and false otherwise
isSetSchema() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
Returns true if field schema is set (has been assigned a value) and false otherwise
isSetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field schemaName is set (has been assigned a value) and false otherwise
isSetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Returns true if field schemaName is set (has been assigned a value) and false otherwise
isSetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
Returns true if field schemaName is set (has been assigned a value) and false otherwise
isSetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field schemaName is set (has been assigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field sd is set (has been assigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field sd is set (has been assigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
Returns true if field sd is set (has been assigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field sd is set (has been assigned a value) and false otherwise
isSetSecret() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
Returns true if field secret is set (has been assigned a value) and false otherwise
isSetSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field serdeInfo is set (has been assigned a value) and false otherwise
isSetSerializationLib() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field serializationLib is set (has been assigned a value) and false otherwise
isSetServerProtocolVersion() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
Returns true if field serverProtocolVersion is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
Returns true if field sessionHandle is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSharedSDPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field sharedSDPartitionSpec is set (has been assigned a value) and false otherwise
isSetSIntString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
Returns true if field sIntString is set (has been assigned a value) and false otherwise
isSetSkewedColNames() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
Returns true if field skewedColNames is set (has been assigned a value) and false otherwise
isSetSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
Returns true if field skewedColValueLocationMaps is set (has been assigned a value) and false otherwise
isSetSkewedColValues() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
Returns true if field skewedColValues is set (has been assigned a value) and false otherwise
isSetSkewedInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field skewedInfo is set (has been assigned a value) and false otherwise
isSetSmallIntValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field sortCols is set (has been assigned a value) and false otherwise
isSetSource_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field source_db is set (has been assigned a value) and false otherwise
isSetSource_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Returns true if field source_table_name is set (has been assigned a value) and false otherwise
isSetSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field SQLState is set (has been assigned a value) and false otherwise
isSetSqlState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field sqlState is set (has been assigned a value) and false otherwise
isSetSqlState() - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field sqlState is set (has been assigned a value) and false otherwise
isSetStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageAttributes is set (has been assigned a value) and false otherwise
isSetStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageCounters is set (has been assigned a value) and false otherwise
isSetStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field stageGraph is set (has been assigned a value) and false otherwise
isSetStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageId is set (has been assigned a value) and false otherwise
isSetStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field stageList is set (has been assigned a value) and false otherwise
isSetStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageType is set (has been assigned a value) and false otherwise
isSetStart() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field start is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStartRowOffset() - Method in class org.apache.hive.service.cli.thrift.TRowSet
Returns true if field startRowOffset is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field state is set (has been assigned a value) and false otherwise
isSetStatement() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Returns true if field statement is set (has been assigned a value) and false otherwise
isSetStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
Returns true if field stats_obj is set (has been assigned a value) and false otherwise
isSetStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
Returns true if field stats_obj is set (has been assigned a value) and false otherwise
isSetStatsData() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
Returns true if field statsData is set (has been assigned a value) and false otherwise
isSetStatsDesc() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
Returns true if field statsDesc is set (has been assigned a value) and false otherwise
isSetStatsObj() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
Returns true if field statsObj is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatusCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
Returns true if field statusCode is set (has been assigned a value) and false otherwise
isSetStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field storedAsSubDirectories is set (has been assigned a value) and false otherwise
isSetStringStats() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
isSetStringVal() - Method in class org.apache.hive.service.cli.thrift.TColumn
 
isSetStringVal() - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
isSetStringValue() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetStringValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
isSetStringValue() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
isSetStructEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccessful() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field successful is set (has been assigned a value) and false otherwise
isSettable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
 
isSettable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field table_name is set (has been assigned a value) and false otherwise
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
Returns true if field table_name is set (has been assigned a value) and false otherwise
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field table_name is set (has been assigned a value) and false otherwise
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
Returns true if field table_name is set (has been assigned a value) and false otherwise
isSetTablename() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Returns true if field tablename is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTablename() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field tablename is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTablename() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field tablename is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field tablename is set (has been assigned a value) and false otherwise
isSetTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field tablename is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableStats() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
Returns true if field tableStats is set (has been assigned a value) and false otherwise
isSetTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field tableType is set (has been assigned a value) and false otherwise
isSetTableTypes() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
Returns true if field tableTypes is set (has been assigned a value) and false otherwise
isSetTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskAttributes is set (has been assigned a value) and false otherwise
isSetTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskCounters is set (has been assigned a value) and false otherwise
isSetTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskId is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field taskTrackers is set (has been assigned a value) and false otherwise
isSetTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskType is set (has been assigned a value) and false otherwise
isSetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Returns true if field tbl is set (has been assigned a value) and false otherwise
isSetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
Returns true if field tbl is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Returns true if field tbl_name is set (has been assigned a value) and false otherwise
isSetTbl_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
Returns true if field tbl_names is set (has been assigned a value) and false otherwise
isSetTblName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
Returns true if field tblName is set (has been assigned a value) and false otherwise
isSetTblName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
Returns true if field tblName is set (has been assigned a value) and false otherwise
isSetTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Returns true if field tblName is set (has been assigned a value) and false otherwise
isSetTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Returns true if field tblName is set (has been assigned a value) and false otherwise
isSetTblName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
Returns true if field tblName is set (has been assigned a value) and false otherwise
isSetTemporary() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field temporary is set (has been assigned a value) and false otherwise
isSetThrow_exception() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
Returns true if field throw_exception is set (has been assigned a value) and false otherwise
isSetToken_owner() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Returns true if field token_owner is set (has been assigned a value) and false otherwise
isSetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Returns true if field token_str_form is set (has been assigned a value) and false otherwise
isSetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Returns true if field token_str_form is set (has been assigned a value) and false otherwise
isSetTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
Returns true if field txn_high_water_mark is set (has been assigned a value) and false otherwise
isSetTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
Returns true if field txn_high_water_mark is set (has been assigned a value) and false otherwise
isSetTxn_ids() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
Returns true if field txn_ids is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field txnid is set (has been assigned a value) and false otherwise
isSetTxns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
Returns true if field txns is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field type1 is set (has been assigned a value) and false otherwise
isSetType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field type2 is set (has been assigned a value) and false otherwise
isSetTypeClassName() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
Returns true if field typeClassName is set (has been assigned a value) and false otherwise
isSetTypeDesc() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
Returns true if field typeDesc is set (has been assigned a value) and false otherwise
isSetTypeQualifiers() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
Returns true if field typeQualifiers is set (has been assigned a value) and false otherwise
isSetTypes() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
Returns true if field types is set (has been assigned a value) and false otherwise
isSetUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field underscore_int is set (has been assigned a value) and false otherwise
isSetUnionEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetUnionField1() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field unionField1 is set (has been assigned a value) and false otherwise
isSetUnionField2() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field unionField2 is set (has been assigned a value) and false otherwise
isSetUnionField3() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field unionField3 is set (has been assigned a value) and false otherwise
isSetUnionMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
isSetUnscaled() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
Returns true if field unscaled is set (has been assigned a value) and false otherwise
isSetUri() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
Returns true if field uri is set (has been assigned a value) and false otherwise
isSetUser() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUser() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUser() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUser() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field user_name is set (has been assigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field user_name is set (has been assigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field user_name is set (has been assigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field user_name is set (has been assigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
Returns true if field user_name is set (has been assigned a value) and false otherwise
isSetUserDefinedTypeEntry() - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
isSetUsername() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
Returns true if field username is set (has been assigned a value) and false otherwise
isSetUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field userPrivileges is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TByteValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TI16Value
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TI32Value
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TI64Value
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hive.service.cli.thrift.TStringValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TI16Column
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TI32Column
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TI64Column
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
Returns true if field values is set (has been assigned a value) and false otherwise
isSetValueTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
Returns true if field valueTypePtr is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field version is set (has been assigned a value) and false otherwise
isSetViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field viewExpandedText is set (has been assigned a value) and false otherwise
isSetViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field viewOriginalText is set (has been assigned a value) and false otherwise
isSetWorkerid() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Returns true if field workerid is set (has been assigned a value) and false otherwise
isShrinked - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
isShrinked() - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
isShuffleGroup() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
isShuffleNone() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
isShuffleSort() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
isShutdown() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
isShutdownInProgress() - Static method in class org.apache.hive.common.util.ShutdownHookManager
Indicates if shutdown is in progress or not.
isSigned(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isSilent - Variable in class org.apache.hadoop.hive.ql.session.SessionState
silent mode.
isSilent - Variable in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
isSimpleSelectQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isSimpleSelectQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
isSimpleSelectQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isSingleRow() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
isSingleRow() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
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.
isSkewedStoredAsSubDirectories - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
isSkippable() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
isSorted - Variable in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
isSortedExpr() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
isSortedFilter() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
isSortedTag(JoinOperator, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
isSourceSequenceGood() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSourceMapping
 
isSplittable(FileSystem, Path) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
Deprecated.
 
isSrcLocal() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
isStar() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
isStar() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
isStarted() - Static method in class org.apache.hadoop.hive.metastore.Deadline
Check whether the timer is started.
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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.metastore.api.StorageDescriptor
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
isStreaming() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFAbstractRankEvaluator
 
isStringFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isStringOrVoidType(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
isSubDir(Path, Path, FileSystem) - Static method in class org.apache.hadoop.hive.common.FileUtils
Check if first path is a subdirectory of second path.
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionContext
 
isSuccess() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
isSuccessful() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
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.
isSupportedField(ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
isSupportedField(String) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
isSupportedKey(ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
isSupportedLocalDriver(Driver) - Method in class org.apache.hive.beeline.BeeLine
 
isSupportsWindow() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isTableExternal(boolean) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
isTableFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isTableFunction(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
isTblLevel() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
isTblLvl() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
isTemp() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
isTemp() - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
isTemporary() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isTemporary - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
isTemporary() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isTemporary() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
isTemporary() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
isTemporary() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
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
 
isTerminal() - Method in enum org.apache.hive.service.cli.OperationState
 
isThrow_exception() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
isThrowException() - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
isTimedOut(long) - Method in class org.apache.hive.service.cli.operation.Operation
 
isTimestampFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isTopLevelSelectStarQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isTopLevelSimpleSelectStarQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
isTxnRangeValid(long, long) - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
isTxnRangeValid(long, long) - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Find out if a range of transaction ids are valid.
isTxnRangeValid(long, long) - Method in class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
isTxnValid(long) - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
isTxnValid(long) - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Indicates whether a given transaction is valid.
isType(String) - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
isUndoable() - Method in interface org.apache.hive.hcatalog.api.repl.Command
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
isUndoable() - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
isUnsignedAttribute() - Method in enum org.apache.hive.service.cli.Type
Is this type unsigned?
isUpdateOrDelete() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
ISupportStreamingModeForWindowing - Interface in org.apache.hadoop.hive.ql.udf.generic
A GenericUDAF mode that provides it results as a List to the WindowingTableFunction (so it is a WindowFunctionInfo.isPivotResult() return true) may support this interface.
isUseBucketizedHiveInputFormat() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
isUseBucketizedHiveInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isUseOneNullRowInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isUserAdmin() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
isUserLevelExplain() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isUserStorageFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
True if user has specified storage format in query
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.
isUtfStartByte(byte) - Static method in class org.apache.hive.common.util.HiveStringUtils
Checks if b is the first byte of a UTF-8 character.
isValid(int) - Method in class org.apache.hive.jdbc.HiveConnection
 
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.hbase.HBaseStatsUtils
Check if a particular statistic type is supported
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.hbase.HBaseStatsUtils
Check if the set to be published is within the supported statistics.
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.
isValue() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
isVariable() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
isVectorGroupBatches() - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
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.
isVectorOutput() - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
isVerbose() - Method in class org.apache.hadoop.hive.common.cli.CommonCliOptions
Should the client be verbose.
isVerbose - Variable in class org.apache.hadoop.hive.ql.session.SessionState
verbose mode
isView(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isView() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isWalked(ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
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
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveConnection
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveDataSource
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isWrapperFor(Class<?>) - Method in class org.apache.hive.jdbc.HiveStatement
 
isWritable(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
isWritable(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
isWritingBase() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
isZero() - Method in class org.apache.hadoop.hive.common.type.Decimal128
 
isZero() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
isZero() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
iter - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
iterate(Double) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
Iterate through one row of original data.
iterate(String[]) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
Iterate through one row of original data.
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
iterate(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
iterate(IntWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
iterate(LongWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
iterate(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
iterate(Text) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
iterate(Double, int) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Iterate through one row of original data.
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
iterate(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
iterate(IntWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
iterate(LongWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
iterate(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
iterate(Text) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
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.GenericUDAFNumericStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
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.hbase.ColumnMappings
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
 
iterator() - Method in class org.apache.hadoop.hive.ql.metadata.PartitionIterable
 
iterator(PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
iterator(PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
iterator() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
iterator() - Method in class org.apache.hive.service.cli.RowBasedSet
 
ITERATOR_PUSHDOWN_DEFAULT - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
ITERATOR_PUSHDOWN_KEY - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 

J

JAR_ARGS_NAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
JAR_COMPLETE - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
JAR_FILE_EXT - Static variable in class org.apache.hive.common.util.HiveTestUtils
 
JAR_ID - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
JarDelegator - Class in org.apache.hive.hcatalog.templeton
Submit a job to the MapReduce queue.
JarDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.JarDelegator
 
jarDir(File, String, ZipOutputStream) - Static method in class org.apache.hadoop.hive.accumulo.Utils
 
jarFileNameExtension - Static variable in class org.apache.hive.beeline.ClassNameCompleter
 
jarFinderGetJar(Class) - Static method in class org.apache.hadoop.hive.accumulo.Utils
Returns the full path to the Jar containing the class.
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
 
JAVA_FILE_EXT - Static variable in class org.apache.hive.common.util.HiveTestUtils
 
JavaAction - Class in org.apache.hive.hcatalog.oozie
 
JavaAction() - Constructor for class org.apache.hive.hcatalog.oozie.JavaAction
 
JavaBinaryObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
JavaBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaBooleanObjectInspector inspects a Java Boolean Object.
javaBooleanObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
javaByteArrayObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaByteObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaByteObjectInspector inspects a Java Byte Object.
javaByteObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaConstantBinaryObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantBinaryObjectInspector(byte[]) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantBinaryObjectInspector
 
JavaConstantBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantBooleanObjectInspector(Boolean) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantBooleanObjectInspector
 
JavaConstantByteObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantByteObjectInspector(Byte) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantByteObjectInspector
 
JavaConstantDateObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantDateObjectInspector(Date) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantDateObjectInspector
 
JavaConstantDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantDoubleObjectInspector(Double) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantDoubleObjectInspector
 
JavaConstantFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantFloatObjectInspector(Float) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantFloatObjectInspector
 
JavaConstantHiveCharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantHiveCharObjectInspector(HiveChar) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveCharObjectInspector
 
JavaConstantHiveDecimalObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantHiveDecimalObjectInspector(HiveDecimal) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveDecimalObjectInspector
 
JavaConstantHiveVarcharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantHiveVarcharObjectInspector(HiveVarchar) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantHiveVarcharObjectInspector
 
JavaConstantIntObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantIntObjectInspector(Integer) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantIntObjectInspector
 
JavaConstantLongObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantLongObjectInspector(Long) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantLongObjectInspector
 
JavaConstantShortObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantShortObjectInspector(Short) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantShortObjectInspector
 
JavaConstantStringObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantStringObjectInspector(String) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantStringObjectInspector
 
JavaConstantTimestampObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaConstantTimestampObjectInspector(Timestamp) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaConstantTimestampObjectInspector
 
JavaDataModel - Enum in org.apache.hadoop.hive.ql.util
Estimation of memory footprint of object
JavaDateObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaDateObjectInspector inspects a Java Date Object.
JavaDateObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
javaDateObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaDoubleObjectInspector inspects a Java Double Object.
javaDoubleObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaFloatObjectInspector inspects a Java Float Object.
javaFloatObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
javaHashEntryOverHead - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
JavaHiveCharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaHiveCharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
JavaHiveCharObjectInspector(CharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
javaHiveCharObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaHiveDecimalObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaHiveDecimalObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
JavaHiveDecimalObjectInspector(DecimalTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
javaHiveDecimalObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaHiveIntervalDayTimeObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaHiveIntervalDayTimeObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
javaHiveIntervalDayTimeObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaHiveIntervalYearMonthObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaHiveIntervalYearMonthObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
javaHiveIntervalYearMonthObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaHiveVarcharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaHiveVarcharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
JavaHiveVarcharObjectInspector(VarcharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
javaHiveVarcharObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaIntObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaIntObjectInspector inspects a Java Integer Object.
javaIntObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaLongObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaLongObjectInspector inspects a Java Long Object.
javaLongObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
javaObjectOverHead - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
JavaShortObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaShortObjectInspector inspects a Java Short Object.
javaShortObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
javaSizePrimitiveType - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
javaSizeUnknownType - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
JavaStringObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaStringObjectInspector inspects a Java String Object.
JavaStringObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
javaStringObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaTimestampObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
JavaTimestampObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
javaTimestampObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
JavaUtils - Class in org.apache.hadoop.hive.common
Collection of Java class loading/reflection related utilities common across Hive.
JavaVoidObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaVoidObjectInspector inspects a Java Void Object.
javaVoidObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
jc - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
jconf - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
JdbcColumn - Class in org.apache.hive.jdbc
Column metadata.
jdbcCompliant() - Method in class org.apache.hive.jdbc.HiveDriver
Returns whether the driver is JDBC compliant.
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
 
JdbcTable - Class in org.apache.hive.jdbc
Table metadata.
JdbcTable(String, String, String, String) - Constructor for class org.apache.hive.jdbc.JdbcTable
 
JdbcUriParseException - Exception in org.apache.hive.jdbc
 
JdbcUriParseException(Throwable) - Constructor for exception org.apache.hive.jdbc.JdbcUriParseException
 
JdbcUriParseException(String) - Constructor for exception org.apache.hive.jdbc.JdbcUriParseException
 
JdbcUriParseException(String, Throwable) - Constructor for exception org.apache.hive.jdbc.JdbcUriParseException
 
JDOConnectionURLHook - Interface in org.apache.hadoop.hive.metastore.hooks
JDOConnectURLHook is used to get the URL that JDO uses to connect to the database that stores the metastore data.
Jetty20SShims - Class in org.apache.hadoop.hive.shims
 
Jetty20SShims() - Constructor for class org.apache.hadoop.hive.shims.Jetty20SShims
 
Jetty23Shims - Class in org.apache.hadoop.hive.shims
Jetty23Shims.
Jetty23Shims() - Constructor for class org.apache.hadoop.hive.shims.Jetty23Shims
 
JettyShims - Interface in org.apache.hadoop.hive.shims
Since Hadoop ships with different versions of Jetty in different versions, Hive uses a shim layer to access the parts of the API that have changed.
JettyShims.Server - Interface in org.apache.hadoop.hive.shims
Server.
jj_nt - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Next token.
jjFillToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
jjstrLiteralImages - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Token literal values.
jjtAddChild(Node, int) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method tells the node to add its argument to the node's list of children.
jjtAddChild(Node, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTASYNC - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtClose() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method is called after all the child nodes have been added.
jjtClose() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTCOMMAORSEMICOLON - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTLISTCONTENTS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTMAP - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTMAPCONTENTS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTVALUE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTDEFINITION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTDEFINITIONTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUM - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUMDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUMDEFLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTEXTENDS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELD - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDREQUIREDNESS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDVALUE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFLAGARGS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFUNCTION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFUNCTIONTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtGetChild(int) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method returns a child node.
jjtGetChild(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtGetNumChildren() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
Return the number of children the node has.
jjtGetNumChildren() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtGetParent() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
 
jjtGetParent() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTHEADER - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTHEADERLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTINCLUDE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTNAMESPACE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtNodeName - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtOpen() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method is called after the node has been made the current node.
jjtOpen() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtree - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
JJTSENUM - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSENUMDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSENUMDEFLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSERVICE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtSetParent(Node) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This pair of methods are used to inform the node of its parent.
jjtSetParent(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTSTART - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSTRUCT - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTthrift_grammarState - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
JJTthrift_grammarState() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
JJTTHROWS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEBOOL - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEBYTE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDEFINITION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDOUBLE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI16 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI32 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI64 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPELIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEMAP - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPESET - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPESTRING - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTUNFLAGARGS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTXCEPTION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
job - Variable in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
job - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
job - Variable in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
job - Variable in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
Job<T extends Serializable> - Interface in org.apache.hive.spark.client
Interface for a Spark remote job.
JOB_PATH - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
job_path - Variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
JOB_TRACKINGPATH - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
job_trackingpath - Variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
JOB_TYPE - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
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.truncate.ColumnTruncateMapper
 
jobCloseOp(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
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
 
jobConf - Variable in class org.apache.hadoop.hive.ql.exec.spark.HivePairFlatMapFunction
 
jobConf - Variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
jobConf - Variable in class org.apache.hadoop.hive.ql.io.avro.AvroContainerInputFormat
 
jobConf - Variable in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
jobConf - Variable in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
JobContext - Interface in org.apache.hive.spark.client
Holds runtime information about the job execution context.
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
 
jobExecHelper - Variable in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
jobExecHelper - Variable in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
jobExecHelper - Variable in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
jobExecHelper - Variable in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
JobHandle<T extends Serializable> - Interface in org.apache.hive.spark.client
A handle to a submitted job.
JobHandle.Listener<T extends Serializable> - Interface in org.apache.hive.spark.client
A listener for monitoring the state of the job in the remote context.
JobHandle.State - Enum in org.apache.hive.spark.client
The current state of the submitted job.
jobId - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
jobID - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
jobIdFormat - Static variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
jobInfo(RunningJob) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
from StreamJob.java.
JobItemBean - Class in org.apache.hive.hcatalog.templeton
 
JobItemBean() - Constructor for class org.apache.hive.hcatalog.templeton.JobItemBean
 
JobItemBean(String, QueueStatusBean) - Constructor for class org.apache.hive.hcatalog.templeton.JobItemBean
Create a new JobItemBean
JobMetricsListener - Class in org.apache.hadoop.hive.ql.exec.spark.status.impl
 
JobMetricsListener() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
JobState - Class in org.apache.hive.hcatalog.templeton.tool
The persistent state of a job.
JobState(String, Configuration) - Constructor for class org.apache.hive.hcatalog.templeton.tool.JobState
 
JobStateTracker - Class in org.apache.hive.hcatalog.templeton.tool
 
JobStateTracker(String, CuratorFramework, boolean, String) - Constructor for class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
Constructor for a new node -- takes the jobid of an existing job
JobSubmissionConstants - Interface in org.apache.hive.hcatalog.templeton.tool
 
JobSubmissionConstants.PigConstants - Interface in org.apache.hive.hcatalog.templeton.tool
constants needed for Pig job submission The string values here are what Pig expects to see in it's environment
JobSubmissionConstants.Sqoop - Interface in org.apache.hive.hcatalog.templeton.tool
 
JobTrackerState - Enum in org.apache.hadoop.hive.service
 
JobTrackerURLResolver - Class in org.apache.hadoop.hive.ql.exec.mr
JobTrackerURLResolver.
join(String...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
JOIN - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule
 
join() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
join(CharSequence, Iterable<?>) - Static method in class org.apache.hive.common.util.HiveStringUtils
Concatenates strings, using a separator.
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
 
JoinCondTypeCheckProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
TODO:
1.
JoinCondTypeCheckProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory
 
JoinCondTypeCheckProcFactory.JoinCondColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
Processor for table columns.
JoinCondTypeCheckProcFactory.JoinCondColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondColumnExprProcessor
 
JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
The default processor for typechecking.
JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor
 
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[], ExprNodeDesc[][]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, boolean, JoinCondDesc[], Map<Byte, List<ExprNodeDesc>>, ExprNodeDesc[][]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(JoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
joinFilterObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The ObjectInspectors for join filters.
joinFilters - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The filters for join
joinKeys - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
The expressions for join inputs's join keys.
joinKeysObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
The ObjectInspectors for the join inputs's join keys.
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
 
joinResult() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
 
joinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
joinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
joinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
joinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
JoinType - Enum in org.apache.hadoop.hive.ql.parse
JoinType.
JoinTypeCheckCtx - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
TODO:
1.
JoinTypeCheckCtx(RowResolver, RowResolver, JoinType) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinTypeCheckCtx
 
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.JoinResult - Enum in org.apache.hadoop.hive.ql.exec
Represents the join result between two tables
joinValues - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The expressions for join inputs.
joinValuesObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The ObjectInspectors for the join inputs.
joinValuesStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The standard ObjectInspectors for the join inputs.
JSONAddPartitionMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of AddPartitionMessage.
JSONAddPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
Default Constructor.
JSONAddPartitionMessage(String, String, String, String, List<Map<String, String>>, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
JSONAlterPartitionMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON alter table message
JSONAlterPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
Default constructor, needed for Jackson.
JSONAlterPartitionMessage(String, String, String, String, Map<String, String>, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
JSONAlterTableMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON alter table message
JSONAlterTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
Default constructor, needed for Jackson.
JSONAlterTableMessage(String, String, String, String, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
JsonBuilder - Class in org.apache.hive.hcatalog.templeton
Helper class to build new json objects with new top level properties.
JSONCreateDatabaseMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON Implementation of CreateDatabaseMessage.
JSONCreateDatabaseMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
Default constructor, required for Jackson.
JSONCreateDatabaseMessage(String, String, String, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
JSONCreateTableMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of CreateTableMessage.
JSONCreateTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
Default constructor, needed for Jackson.
JSONCreateTableMessage(String, String, String, String, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
JSONDropDatabaseMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of DropDatabaseMessage.
JSONDropDatabaseMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
Default constructor, required for Jackson.
JSONDropDatabaseMessage(String, String, String, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
JSONDropPartitionMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of DropPartitionMessage.
JSONDropPartitionMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
Default Constructor.
JSONDropPartitionMessage(String, String, String, String, List<Map<String, String>>, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
JSONDropTableMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of DropTableMessage.
JSONDropTableMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
Default constructor, needed for Jackson.
JSONDropTableMessage(String, String, String, String, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
JSONInsertMessage - Class in org.apache.hive.hcatalog.messaging.json
JSON implementation of DropTableMessage.
JSONInsertMessage() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
Default constructor, needed for Jackson.
JSONInsertMessage(String, String, String, String, Map<String, String>, List<String>, Long) - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
JSONMessageDeserializer - Class in org.apache.hive.hcatalog.messaging.json
MessageDeserializer implementation, for deserializing from JSON strings.
JSONMessageDeserializer() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONMessageDeserializer
 
JSONMessageFactory - Class in org.apache.hive.hcatalog.messaging.json
The JSON implementation of the MessageFactory.
JSONMessageFactory() - Constructor for class org.apache.hive.hcatalog.messaging.json.JSONMessageFactory
 
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
 
JsonParser - Interface in org.apache.hadoop.hive.common.jsonexplain
JsonParser is the interface for classes that print a JSONObject into outputStream.
JsonParserFactory - Class in org.apache.hadoop.hive.common.jsonexplain
 
JsonSerDe - Class in org.apache.hive.hcatalog.data
 
JsonSerDe() - Constructor for class org.apache.hive.hcatalog.data.JsonSerDe
 
jsonToMap(String) - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Convert a json string to a Map.
jvmGCTime - Variable in class org.apache.hive.spark.client.metrics.Metrics
Amount of time the JVM spent in garbage collection while executing tasks.

K

KEEP_ALIVE_MSEC - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
KERBEROS_KEYTAB - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
KERBEROS_PRINCIPAL - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
KERBEROS_SECRET - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
kerberosKeytab() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
kerberosPrincipal() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
KerberosSaslHelper - Class in org.apache.hive.service.auth
 
kerberosSecret() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
key - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
keyBuffer - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
keyEncoding - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
keyEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
The evaluators for the key columns.
keyExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
keyInspector - Variable in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
keyIsText - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
keyLength - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
keyMapping - Variable in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
keyName - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
keyObjectInspector - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
keyProperty() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
keyReader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.MapTreeReader
 
keysAssigned - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
keySerializer - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
keyStore - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
KeyValueContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
An eager key/value container that puts every row directly to output stream.
KeyValueContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
KeyValueInputMerger - 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.
KeyValueInputMerger(List<KeyValueReader>, Deserializer, ObjectInspector[], List<String>) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger
 
keyValueProperty() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KeyValuesInputMerger - 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.
KeyValuesInputMerger(List<? extends Input>) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValuesInputMerger
 
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
 
keyWritable - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
killIt() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a callback style function used by the HiveSessionManager.
killJob(JobID) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Kill a job.
killJob(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Kill a job.
killJob(JobID) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Kill a job.
killJobs(String, long) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.WebHCatJTShim
Kills all jobs tagged with the given tag that have been started after the given timestamp.
killJobs(String, long) - Method in class org.apache.hadoop.mapred.WebHCatJTShim20S
Kill jobs is only supported on hadoop 2.0+.
killJobs(String, long) - Method in class org.apache.hadoop.mapred.WebHCatJTShim23
Kills all jobs tagged with the given tag that have been started after the given timestamp.
killRunningJobs() - Static method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
killRunningJobs() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezJobExecHelper
 
killRunningJobs() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
killRunningJobs tries to terminate execution of all currently running tez queries.
kind - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
An integer that describes the kind of this token.
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
KryoSerializer - Class in org.apache.hadoop.hive.ql.exec.spark
 
KryoSerializer() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.KryoSerializer
 
KW_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ADMIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ADMIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ADMIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ADMIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ADMIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ALTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ALTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ALTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ALTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ALTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_AND - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
KW_AND - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
KW_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ARRAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ARRAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ARRAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ARRAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ARRAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_AS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_AS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_AS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_AS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_AS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BEFORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BEFORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BEFORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BEFORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BEFORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BETWEEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BETWEEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BETWEEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BETWEEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BETWEEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BOTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BOTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BOTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BOTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BOTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BUCKET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BUCKET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BUCKET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BUCKET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BUCKET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_BY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_BY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_BY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_BY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_BY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CAST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CAST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CAST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CAST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CAST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CLUSTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CLUSTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CLUSTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CLUSTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CLUSTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CLUSTERSTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CLUSTERSTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CLUSTERSTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CLUSTERSTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CLUSTERSTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COLLECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COLLECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COLLECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COLLECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COLLECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CONCATENATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CONCATENATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CONCATENATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CONCATENATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CONCATENATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CONTINUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CONTINUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CONTINUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CONTINUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CONTINUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CROSS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CROSS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CROSS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CROSS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CROSS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CUBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CUBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CUBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CUBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CUBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CURRENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CURRENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CURRENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CURRENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CURRENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CURRENT_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CURRENT_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CURRENT_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CURRENT_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CURRENT_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CURRENT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CURRENT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CURRENT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CURRENT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CURRENT_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_CURSOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CURSOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_CURSOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_CURSOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_CURSOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DATE - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
KW_DATE - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
KW_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DAY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DEFINED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DEFINED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DEFINED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DEFINED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DEFINED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DELIMITED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DELIMITED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DELIMITED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DELIMITED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DELIMITED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DEPENDENCY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DEPENDENCY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DEPENDENCY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DEPENDENCY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DEPENDENCY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DESCRIBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DESCRIBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DESCRIBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DESCRIBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DESCRIBE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DIRECTORIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DIRECTORIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DIRECTORIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DIRECTORIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DIRECTORIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DIRECTORY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DIRECTORY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DIRECTORY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DIRECTORY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DIRECTORY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DISTRIBUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DISTRIBUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DISTRIBUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DISTRIBUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DISTRIBUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ELEM_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ELEM_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ELEM_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ELEM_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ELEM_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ELSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ELSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ELSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ELSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ELSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_END - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_END - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_END - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_END - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_END - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ESCAPED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ESCAPED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ESCAPED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ESCAPED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ESCAPED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXCHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXCHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXCHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXCHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXCHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXTENDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXTENDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXTENDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXTENDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXTENDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_EXTERNAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXTERNAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_EXTERNAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_EXTERNAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_EXTERNAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FETCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FETCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FETCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FETCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FETCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FIELDS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FIELDS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FIELDS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FIELDS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FIELDS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FOLLOWING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FOLLOWING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FOLLOWING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FOLLOWING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FOLLOWING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_FUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_FUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_FUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_GROUPING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_GROUPING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_GROUPING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_GROUPING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_GROUPING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_HOUR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_HOUR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_HOUR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_HOUR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_HOUR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IGNORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IGNORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IGNORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IGNORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IGNORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INPATH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INPATH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INPATH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INPATH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INPATH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INTERSECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INTERSECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INTERSECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INTERSECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INTERSECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_IS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_IS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_IS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_KEY_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_KEY_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_KEY_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_KEY_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_KEY_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_KEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_KEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_KEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_KEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_KEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LEFT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LEFT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LEFT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LEFT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LEFT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LESS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LESS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LESS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LESS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LESS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOCAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOCAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOCAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOCAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOCAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LOGICAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOGICAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LOGICAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LOGICAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LOGICAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_LONG - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LONG - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_LONG - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_LONG - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_LONG - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MATERIALIZED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MATERIALIZED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MATERIALIZED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MATERIALIZED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MATERIALIZED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MINUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MINUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MINUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MINUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MINUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MORE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_NONE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NONE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_NONE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_NONE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_NONE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_NOSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NOSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_NOSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_NOSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_NOSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_NOT - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
KW_NOT - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
KW_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OR - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
KW_OR - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
KW_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ORDER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ORDER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ORDER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ORDER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ORDER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OUT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OUT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OUT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OUT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OUT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OVERWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OVERWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OVERWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OVERWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OVERWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PARTIALSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PARTIALSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PARTIALSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PARTIALSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PARTIALSCAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PARTITIONED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PARTITIONED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PARTITIONED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PARTITIONED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PARTITIONED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PRECEDING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PRECEDING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PRECEDING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PRECEDING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PRECEDING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PRETTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PRETTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PRETTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PRETTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PRETTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PROCEDURE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PROCEDURE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PROCEDURE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PROCEDURE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PROCEDURE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_PURGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PURGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_PURGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_PURGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_PURGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_READ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_READ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_READ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_READ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_READ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_READS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_READS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_READS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_READS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_READS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REGEXP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REGEXP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REGEXP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REGEXP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REGEXP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RELOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RELOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RELOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RELOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RELOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RIGHT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RIGHT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RIGHT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RIGHT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RIGHT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_RLIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RLIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RLIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_RLIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_RLIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ROLLUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ROLLUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ROLLUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ROLLUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ROLLUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_ROWS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ROWS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_ROWS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_ROWS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_ROWS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SCHEMAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SCHEMAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SCHEMAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SCHEMAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SCHEMAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SECOND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SECOND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SECOND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SECOND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SECOND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SERVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SERVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SERVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SERVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SERVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_SSL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SSL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SSL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_SSL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_SSL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_STORED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STORED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_STORED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_STORED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_STORED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TERMINATED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TERMINATED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TERMINATED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TERMINATED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TERMINATED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_THEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_THEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_THEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_THEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_THEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TRIGGER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TRIGGER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TRIGGER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TRIGGER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TRIGGER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_TRUNCATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TRUNCATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_TRUNCATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_TRUNCATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_TRUNCATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNBOUNDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNBOUNDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNBOUNDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNBOUNDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNBOUNDED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNDO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNDO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNDO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNDO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNDO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNLOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNLOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNLOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNLOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNLOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNSET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNSET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNSET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNSET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNSET - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UNSIGNED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNSIGNED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNSIGNED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UNSIGNED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UNSIGNED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_USING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_USING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_USING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_USING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_USING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UTC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UTC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UTC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UTC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UTC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_UTCTIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UTCTIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UTCTIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_UTCTIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_UTCTIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_VALUE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_VALUE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_VALUE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_VALUE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_VALUE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_VALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_VALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_VALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_VALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_VALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_WHEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_WHEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_WHEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_WHEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_WHEN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_WHILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_WHILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_WHILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_WHILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_WHILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_WINDOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_WINDOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_WINDOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_WINDOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_WINDOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_WITH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_WITH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_WITH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_WITH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_WITH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
KW_YEAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_YEAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_YEAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
KW_YEAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
KW_YEAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 

L

l4j - Static variable in class org.apache.hadoop.hive.cli.OptionsProcessor
 
l4j - Static variable in class org.apache.hadoop.hive.hwi.HWIContextListener
 
l4j - Static variable in class org.apache.hadoop.hive.hwi.HWIServer
 
l4j - Static variable in class org.apache.hadoop.hive.hwi.HWISessionItem
 
l4j - Static variable in class org.apache.hadoop.hive.hwi.HWISessionManager
 
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.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.ReduceRecordSource
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValuesInputMerger
 
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.metastore.parser.ExpressionTree.ANTLRNoCaseStringStream
 
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
 
largestNumberOfSteps - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
last() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
LAST_VALUE_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
lastColumnTakesRest - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
lastDay(Date) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLastDay
 
lastException - Variable in class org.apache.hive.beeline.AbstractCommandHandler
 
lastIndexOf(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
lastMapProgress - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
lastOperationDeserialize - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
lastOperationSerialize - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
lastPrimitiveWasNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
lastPrimitiveWasNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
lastPrimitiveWasNull() - Method in interface org.apache.hadoop.hive.serde2.thrift.WriteNullsProtocol
Was the last primitive read really a NULL.
lastPrimitiveWasNullFlag - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
lastReduceProgress - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
lastSeenSyncPos() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns the last seen sync position.
lastStripeInFile - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
lateralView() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
lateralView() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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
 
LATEST_COMPAT_LEVEL - Static variable in class org.apache.hive.common.HiveCompat
 
LauncherDelegator - Class in org.apache.hive.hcatalog.templeton
The helper class for all the Templeton delegator classes that launch child jobs.
LauncherDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.LauncherDelegator
 
LauncherDelegator.JobType - Enum in org.apache.hive.hcatalog.templeton
 
launching(TaskRunner) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
LaunchMapper - Class in org.apache.hive.hcatalog.templeton.tool
Note that this class is used in a different JVM than WebHCat server.
LaunchMapper() - Constructor for class org.apache.hive.hcatalog.templeton.tool.LaunchMapper
 
LAZY_BINARY_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_BOOLEAN_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_BYTE_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_DATE_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_DOUBLE_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_EXT_BOOLEAN_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_FLOAT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_INT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_INTERVAL_DAY_TIME_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_INTERVAL_YEAR_MONTH_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_LONG_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_SHORT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_TIMESTAMP_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_VOID_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LazyAccumuloMap - Class in org.apache.hadoop.hive.accumulo
A Hive Map created from some collection of Key-Values from one to many column families with one to many column qualifiers.
LazyAccumuloMap(LazyMapObjectInspector) - Constructor for class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
LazyAccumuloRow - Class in org.apache.hadoop.hive.accumulo
Parses column tuples in each AccumuloHiveRow and creates Lazy objects for each field.
LazyAccumuloRow(LazySimpleStructObjectInspector) - Constructor for class org.apache.hadoop.hive.accumulo.LazyAccumuloRow
 
LazyArray - Class in org.apache.hadoop.hive.serde2.lazy
LazyArray stores an array of Lazy Objects.
LazyArray(LazyListObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyArray
Construct a LazyArray object with the ObjectInspector.
LazyBinary - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyBinary(LazyBinary) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyBinary
 
LazyBinaryArray - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryArray is serialized as follows: start A b b b b b b end bytes[] -> |--------|---|---|---|---| ...
LazyBinaryArray(LazyBinaryListObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Construct a LazyBinaryArray object with the ObjectInspector.
LazyBinaryBinary - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryBinary(WritableBinaryObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryBinary
 
LazyBinaryBoolean - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for boolean which takes one byte
LazyBinaryBoolean(WritableBooleanObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryBoolean
 
LazyBinaryBoolean(LazyBinaryBoolean) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryBoolean
 
LazyBinaryByte - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for byte which takes one byte.
LazyBinaryColumnarSerDe - Class in org.apache.hadoop.hive.serde2.columnar
LazyBinaryColumnarSerDe.
LazyBinaryColumnarSerDe() - Constructor for class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe
 
LazyBinaryColumnarStruct - Class in org.apache.hadoop.hive.serde2.columnar
 
LazyBinaryColumnarStruct(ObjectInspector, List<Integer>) - Constructor for class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarStruct
 
LazyBinaryDate - Class in org.apache.hadoop.hive.serde2.lazybinary
A LazyBinaryObject that encodes a java.sql.Date in a VInt.
LazyBinaryDeserializeRead - Class in org.apache.hadoop.hive.serde2.lazybinary.fast
 
LazyBinaryDeserializeRead(PrimitiveTypeInfo[]) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
LazyBinaryDouble - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for double which takes eight bytes.
LazyBinaryFactory - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryFactory.
LazyBinaryFloat - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for float which takes four bytes.
LazyBinaryHiveChar - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryHiveDecimal - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryHiveIntervalDayTime - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryHiveIntervalDayTime A LazyBinaryObject that encodes a HiveIntervalDayTime
LazyBinaryHiveIntervalYearMonth - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryHiveIntervalYearMonth A LazyBinaryObject that encodes a HiveIntervalYearMonth
LazyBinaryHiveVarchar - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryInteger - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for integer which is serialized as VInt.
LazyBinaryListObjectInspector - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspector for LazyBinaryList.
LazyBinaryListObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryListObjectInspector
 
LazyBinaryListObjectInspector(ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryListObjectInspector
 
LazyBinaryLong - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for long which stores as VLong.
LazyBinaryMap - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryMap is serialized as follows: start A b c b c b c end bytes[] -> |--------|---|---|---|---| ...
LazyBinaryMap(LazyBinaryMapObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
 
LazyBinaryMapObjectInspector - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspector for LazyBinaryMap.
LazyBinaryMapObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryMapObjectInspector
 
LazyBinaryMapObjectInspector(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryMapObjectInspector
 
LazyBinaryNonPrimitive<OI extends ObjectInspector> - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryNonPrimitive.
LazyBinaryNonPrimitive(OI) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
LazyBinaryObject<OI extends ObjectInspector> - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject stores an object in a binary format in a byte[].
LazyBinaryObject(OI) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryObject
Create a LazyBinaryObject.
LazyBinaryObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyBinaryObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBinaryObjectInspector
 
LazyBinaryObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazyBinaryPrimitive<OI extends ObjectInspector,T extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.serde2.lazybinary
Defines a LazyBinaryPrimitive.
LazyBinarySerDe - Class in org.apache.hadoop.hive.serde2.lazybinary
The LazyBinarySerDe class combines the lazy property of LazySimpleSerDe class and the binary property of BinarySortable class.
LazyBinarySerDe() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
 
LazyBinarySerDe.BooleanRef - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinarySerDe.BooleanRef(boolean) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.BooleanRef
 
LazyBinarySerDe.StringWrapper - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinarySerDe.StringWrapper() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.StringWrapper
 
LazyBinarySerializeWrite - Class in org.apache.hadoop.hive.serde2.lazybinary.fast
 
LazyBinarySerializeWrite(int) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
LazyBinaryShort - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for short which takes two bytes.
LazyBinaryString - Class in org.apache.hadoop.hive.serde2.lazybinary
The serialization of LazyBinaryString is very simple: start A end bytes[] -> |---------------------------------| Section A is just an array of bytes which are exactly the Text contained in this object.
LazyBinaryString(LazyBinaryString) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryString
 
LazyBinaryStruct - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryStruct is serialized as follows: start A B A B A B end bytes[] -> |-----|---------|--- ...
LazyBinaryStruct(LazyBinaryStructObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
Construct a LazyBinaryStruct object with an ObjectInspector.
LazyBinaryStruct.SingleFieldGetter - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryStruct.SingleFieldGetter(LazyBinaryStructObjectInspector, int) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct.SingleFieldGetter
 
LazyBinaryStructObjectInspector - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspector for LazyBinaryStruct.
LazyBinaryStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
LazyBinaryStructObjectInspector(List<String>, List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
LazyBinaryStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
LazyBinaryStructObjectInspector(List<StructField>) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryStructObjectInspector
 
LazyBinaryTimestamp - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryTimestamp A LazyBinaryObject that encodes a java.sql.Timestamp 4 to 9 bytes.
LazyBinaryUnion - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryUnion is serialized as follows: start TAG FIELD end bytes[] -> |-----|---------|--- ...
LazyBinaryUnion(LazyBinaryUnionObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUnion
Construct a LazyBinaryUnion object with an ObjectInspector.
LazyBinaryUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspector for LazyBinaryUnion.
LazyBinaryUnionObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryUnionObjectInspector
 
LazyBinaryUnionObjectInspector(List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryUnionObjectInspector
 
LazyBinaryUtils - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryUtils.
LazyBinaryUtils.RecordInfo - Class in org.apache.hadoop.hive.serde2.lazybinary
Record is the unit that data is serialized in.
LazyBinaryUtils.RecordInfo() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
LazyBinaryUtils.VInt - Class in org.apache.hadoop.hive.serde2.lazybinary
A zero-compressed encoded integer.
LazyBinaryUtils.VInt() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VInt
 
LazyBinaryUtils.VLong - Class in org.apache.hadoop.hive.serde2.lazybinary
A zero-compressed encoded long.
LazyBinaryUtils.VLong() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
LazyBinaryVoid - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryVoid for NULL which is a placeholder class and it does not need to store any data.
LazyBoolean - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of boolean.
LazyBoolean(LazyBooleanObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyBoolean
 
LazyBoolean(LazyBoolean) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyBoolean
 
LazyBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableBooleanObjectInspector inspects a BooleanWritable Object.
LazyByte - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Byte.
LazyByte(LazyByteObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyByte
 
LazyByte(LazyByte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyByte
 
LazyByteObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableByteObjectInspector inspects a ByteWritable Object.
LazyDate - Class in org.apache.hadoop.hive.serde2.lazy
LazyDate.
LazyDate(LazyDateObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDate
 
LazyDate(LazyDate) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDate
 
LazyDateObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableDateObjectInspector inspects a DateWritable Object.
LazyDateObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyDateObjectInspector
 
LazyDecompressionCallback - Interface in org.apache.hadoop.hive.serde2.columnar
Used to call back lazy decompression process.
LazyDioBoolean - Class in org.apache.hadoop.hive.serde2.lazydio
LazyBooleanBinary for storing a boolean value as an BooleanWritable.
LazyDioBoolean(LazyBooleanObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioBoolean
 
LazyDioBoolean(LazyDioBoolean) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioBoolean
 
LazyDioByte - Class in org.apache.hadoop.hive.serde2.lazydio
LazyByteBinary for storing a byte value as a ByteWritable.
LazyDioByte(LazyByteObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioByte
 
LazyDioByte(LazyDioByte) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioByte
 
LazyDioDouble - Class in org.apache.hadoop.hive.serde2.lazydio
LazyDoubleBinary for storing a double value as a DoubleWritable.
LazyDioDouble(LazyDoubleObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioDouble
 
LazyDioFloat - Class in org.apache.hadoop.hive.serde2.lazydio
LazyFloatBinary for storing a float value as a FloatWritable.
LazyDioFloat(LazyFloatObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioFloat
 
LazyDioFloat(LazyDioFloat) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioFloat
 
LazyDioInteger - Class in org.apache.hadoop.hive.serde2.lazydio
LazyIntegerBinary for storing an int value as an IntWritable.
LazyDioInteger(LazyIntObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioInteger
 
LazyDioInteger(LazyDioInteger) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioInteger
 
LazyDioLong - Class in org.apache.hadoop.hive.serde2.lazydio
LazyLongBinary for storing a long value as a LongWritable.
LazyDioLong(LazyLongObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioLong
 
LazyDioLong(LazyDioLong) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioLong
 
LazyDioShort - Class in org.apache.hadoop.hive.serde2.lazydio
LazyShortBinary for storing a short value as a ShortWritable.
LazyDioShort(LazyShortObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioShort
 
LazyDioShort(LazyDioShort) - Constructor for class org.apache.hadoop.hive.serde2.lazydio.LazyDioShort
 
LazyDouble - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Double.
LazyDouble(LazyDoubleObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDouble
 
LazyDouble(LazyDouble) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDouble
 
LazyDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableDoubleObjectInspector inspects a DoubleWritable Object.
LazyFactory - Class in org.apache.hadoop.hive.serde2.lazy
LazyFactory.
LazyFloat - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Double.
LazyFloat(LazyFloatObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyFloat
 
LazyFloat(LazyFloat) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyFloat
 
LazyFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A FloatObjectInspector inspects a FloatWritable Object.
LazyHBaseCellMap - Class in org.apache.hadoop.hive.hbase
LazyHBaseCellMap refines LazyMap with HBase column mapping.
LazyHBaseCellMap(LazyMapObjectInspector) - Constructor for class org.apache.hadoop.hive.hbase.LazyHBaseCellMap
Construct a LazyCellMap object with the ObjectInspector.
LazyHBaseRow - Class in org.apache.hadoop.hive.hbase
LazyObject for storing an HBase row.
LazyHBaseRow(LazySimpleStructObjectInspector, HBaseSerDeParameters) - Constructor for class org.apache.hadoop.hive.hbase.LazyHBaseRow
Construct a LazyHBaseRow object with the ObjectInspector.
LazyHCatRecord - Class in org.apache.hive.hcatalog.data
An implementation of HCatRecord that wraps an Object returned by a SerDe and an ObjectInspector.
LazyHCatRecord(Object, ObjectInspector) - Constructor for class org.apache.hive.hcatalog.data.LazyHCatRecord
 
LazyHiveChar - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of HiveChar.
LazyHiveChar(LazyHiveCharObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveChar
 
LazyHiveChar(LazyHiveChar) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveChar
 
LazyHiveCharObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyHiveCharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
LazyHiveCharObjectInspector(CharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
LazyHiveCharObjectInspector(CharTypeInfo, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
LazyHiveDecimal - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyHiveDecimal(LazyHiveDecimalObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal
 
LazyHiveDecimal(LazyHiveDecimal) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal
 
LazyHiveDecimalObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyHiveDecimalObjectInspector(DecimalTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveDecimalObjectInspector
 
LazyHiveIntervalDayTime - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyHiveIntervalDayTime(LazyHiveIntervalDayTimeObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalDayTime
 
LazyHiveIntervalDayTime(LazyHiveIntervalDayTime) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalDayTime
 
LazyHiveIntervalDayTimeObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyHiveIntervalYearMonth - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyHiveIntervalYearMonth(LazyHiveIntervalYearMonthObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalYearMonth
 
LazyHiveIntervalYearMonth(LazyHiveIntervalYearMonth) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalYearMonth
 
LazyHiveIntervalYearMonthObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyHiveVarchar - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of HiveVarchar.
LazyHiveVarchar(LazyHiveVarcharObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveVarchar
 
LazyHiveVarchar(LazyHiveVarchar) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyHiveVarchar
 
LazyHiveVarcharObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyHiveVarcharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
LazyHiveVarcharObjectInspector(VarcharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
LazyHiveVarcharObjectInspector(VarcharTypeInfo, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
LazyInteger - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Integer.
LazyInteger(LazyIntObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
LazyInteger(LazyInteger) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
LazyIntObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableIntObjectInspector inspects a IntWritable Object.
LazyListObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyListObjectInspector works on array data that is stored in LazyArray.
LazyListObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
LazyListObjectInspector(ObjectInspector, byte, LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
Call ObjectInspectorFactory.getLazySimpleListObjectInspector instead.
LazyLong - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Long.
LazyLong(LazyLongObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyLong
 
LazyLong(LazyLong) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyLong
 
LazyLongObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableLongObjectInspector inspects a LongWritable Object.
LazyMap - Class in org.apache.hadoop.hive.serde2.lazy
LazyMap stores a map of Primitive LazyObjects to LazyObjects.
LazyMap(LazyMapObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyMap
Construct a LazyMap object with the ObjectInspector.
LazyMapObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyMapObjectInspector works on struct data that is stored in LazyStruct.
LazyMapObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
LazyMapObjectInspector(ObjectInspector, ObjectInspector, byte, byte, Text, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
LazyMapObjectInspector(ObjectInspector, ObjectInspector, byte, byte, LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
LazyNonPrimitive<OI extends ObjectInspector> - Class in org.apache.hadoop.hive.serde2.lazy
LazyPrimitive stores a primitive Object in a LazyObject.
LazyNonPrimitive(OI) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
Create a LazyNonPrimitive object with the specified ObjectInspector.
LazyObject<OI extends ObjectInspector> - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject stores an object in a range of bytes in a byte[].
LazyObject(OI) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyObject
Create a LazyObject.
LazyObjectBase - Interface in org.apache.hadoop.hive.serde2.lazy
 
LazyObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazyObjectInspectorParameters - Interface in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyObjectInspectorParametersImpl - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyObjectInspectorParametersImpl() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
LazyObjectInspectorParametersImpl(boolean, byte, boolean, List<String>, byte[], Text) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
LazyObjectInspectorParametersImpl(boolean, byte, boolean, List<String>, byte[], Text, boolean) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
LazyObjectInspectorParametersImpl(LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
LazyPrimitive<OI extends ObjectInspector,T extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.serde2.lazy
LazyPrimitive stores a primitive Object in a LazyObject.
LazyPrimitive(OI) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
LazyPrimitive(LazyPrimitive<OI, T>) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
LazyPrimitiveObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
LazyPrimitiveObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazySerDeParameters - Class in org.apache.hadoop.hive.serde2.lazy
SerDeParameters.
LazySerDeParameters(Configuration, Properties, String) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
LazyShort - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Short.
LazyShort(LazyShortObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyShort
 
LazyShort(LazyShort) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyShort
 
LazyShortObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableShortObjectInspector inspects a ShortWritable Object.
LazySimpleDeserializeRead - Class in org.apache.hadoop.hive.serde2.lazy.fast
 
LazySimpleDeserializeRead(PrimitiveTypeInfo[], byte, LazySerDeParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
LazySimpleSerDe - Class in org.apache.hadoop.hive.serde2.lazy
LazySimpleSerDe can be used to read the same data format as MetadataTypedColumnsetSerDe and TCTLSeparatedProtocol.
LazySimpleSerDe() - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
LazySimpleSerializeWrite - Class in org.apache.hadoop.hive.serde2.lazy.fast
 
LazySimpleSerializeWrite(int, byte, LazySerDeParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
LazySimpleStructObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazySimpleStructObjectInspector works on struct data that is stored in LazyStruct.
LazySimpleStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
LazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
Deprecated.
LazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, Text, boolean, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
Deprecated.
LazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, List<String>, byte, LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
LazyString - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of String.
LazyString(LazyStringObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyString
 
LazyString(LazyString) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyString
 
LazyStringObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableStringObjectInspector inspects a Text Object.
LazyStringObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
LazyStruct - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a struct.
LazyStruct(LazySimpleStructObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyStruct
Construct a LazyStruct object with the ObjectInspector.
LazyTimestamp - Class in org.apache.hadoop.hive.serde2.lazy
LazyTimestamp.
LazyTimestamp(LazyTimestampObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyTimestamp
 
LazyTimestamp(LazyTimestamp) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyTimestamp
 
LazyTimestampObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
LazyUnion - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a union.
LazyUnion(LazyUnionObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Construct a LazyUnion object with the ObjectInspector.
LazyUnion(LazyUnionObjectInspector, byte, Object) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyUnion
 
LazyUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyUnionObjectInspector works on union data that is stored in LazyUnion.
LazyUnionObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
LazyUnionObjectInspector(List<ObjectInspector>, byte, LazyObjectInspectorParameters) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
LazyUtils - Class in org.apache.hadoop.hive.serde2.lazy
LazyUtils.
LazyVoid - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyVoidObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableVoidObjectInspector inspects a NullWritable Object.
lbCtx - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
LBRACE - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
LBRACKET - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
LBRACKET - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
LCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
LCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
LCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
LdapAuthenticationProviderImpl - Class in org.apache.hive.service.auth
 
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
 
LeafFilterFactory - Class in org.apache.hadoop.hive.ql.io.parquet
 
LeafFilterFactory() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.LeafFilterFactory
 
leafOperatorToFollowingWork - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
leafOpToFollowingWorkInfo - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
leastRow - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
LEFT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
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
 
leftOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
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
 
length - Variable in class org.apache.hadoop.hive.ql.io.orc.InStream
 
length - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadBytesResults
 
length - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
length - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
length - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.StringWrapper
 
length - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VInt
 
length - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
LENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
LENGTH_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
LENGTH = 2;
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
 
lengths - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BinaryTreeReader
 
lengths - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ListTreeReader
 
lengths - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.MapTreeReader
 
lengths - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDirectTreeReader
 
lenValue(long) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
lessThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
lessThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
LessThan - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to lessThan over PrimitiveComparison instance.
LessThan() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.LessThan
 
LessThan(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.LessThan
 
lessThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
lessThan(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
lessThan(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
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.
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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.
lessThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
lessThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
LessThanOrEqual - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to lessThanOrEqual over PrimitiveComparison instance.
LessThanOrEqual() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.LessThanOrEqual
 
LessThanOrEqual(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.LessThanOrEqual
 
lessThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
lessThanOrEqual(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
lessThanOrEqual(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
Letter - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
Letter - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
Letter - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Letter - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Letter - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
Letter - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Letter - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
LETTER - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Lexer state names.
LIB_JARS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants.Sqoop
comma-separated list of jar names (short name) which are needed for Sqoop JDBC access
LIB_JARS_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
libJars() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
lightEscapeString(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
lightEscapeString(String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
like(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
not supported for this PrimitiveCompare implementation.
like(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
Like - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to like over PrimitiveComparison instance.
Like() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.Like
 
Like(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.Like
 
like(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
like(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
like(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
likePatternToRegExp(String) - Static method in class org.apache.hadoop.hive.ql.udf.UDFLike
 
limit - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
limitClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
limitDecimalTo2(double) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
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
 
limitRelNode(RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
line - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
LINE_DELIM - Static variable in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
LINE_DELIM - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
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.
LinearExtrapolatePartStatus - Class in org.apache.hadoop.hive.metastore
 
LinearExtrapolatePartStatus() - Constructor for class org.apache.hadoop.hive.metastore.LinearExtrapolatePartStatus
 
LINES_TO_FETCH - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
linesTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
linesTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
linesTerminatedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
linfo - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Lineage information for the query.
linfo - Variable in class org.apache.hadoop.hive.ql.QueryPlan
Lineage information for the query.
linkChildOpWithDummyOp - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
linkChildOpWithDummyOp - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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
 
linkOpWithWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
linkWorkWithReduceSinkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
linkWorkWithReduceSinkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
LINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
LINTSTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
list() - Method in class org.apache.hadoop.hive.ant.DistinctElementsClassPath
Returns the list of path elements after removing the duplicate files from the original Path
list() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
list(String) - Method in class org.apache.hive.beeline.Commands
List the current connections
LIST - Static variable in class org.apache.hive.hcatalog.data.DataType
 
LIST_COLUMN_COMMENTS - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
LIST_COLUMN_TYPES - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
LIST_COLUMNS - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
list_privileges(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
list_privileges(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Return the privileges that this principal has directly over the object (not through roles).
list_resource(SessionState.ResourceType, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
list_roles(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
list_roles(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
list_roles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
list_roles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
LIST_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
LIST_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
LIST = 10;
listAllTableGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listAllTableGrants(String, PrincipalType, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listAllTableGrants(String, PrincipalType, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
ListBucketingCtx - Class in org.apache.hadoop.hive.ql.plan
Context for list bucketing.
ListBucketingCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
listBucketingDepth - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
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
 
listColumns(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of the columns.
listColumns(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
List the columns in an hcat table.
listDatabaseNamesByPattern(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Get all existing databases that match the given pattern.
listDatabaseNamesByPattern(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
listDatabases(String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json "show databases like".
listDatabases(String) - Method in class org.apache.hive.hcatalog.templeton.Server
List all databases, or those that match a pattern.
listDBGrantsAll(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listDBGrantsAll(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
ListDelegator - Class in org.apache.hive.hcatalog.templeton
List jobs owned by a user.
ListDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.ListDelegator
 
ListenerEvent - Class in org.apache.hadoop.hive.metastore.events
Base class for all the events which are defined for metastore.
ListenerEvent(boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.ListenerEvent
 
listFSRoots() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following API - listFSRoots is used by HiveMetaTool.
listGlobalGrantsAll() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listGlobalGrantsAll() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listIndexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
list all the index names of the give base table.
listIndexes(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list indexes of the give base table
listIndexNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
list indexes of the give base table
listIndexNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list all the index names of the give base table.
listIndexNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listIndexNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listIterator() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
listIterator(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
listLocatedStatus(FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
listLocatedStatus(FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
listLocatedStatus(FileSystem, Path, PathFilter) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get the block locations for the given directory.
ListObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
ListObjectInspector.
ListObjectsEqualComparer - Class in org.apache.hadoop.hive.serde2.objectinspector
Compare two list of objects.
ListObjectsEqualComparer(ObjectInspector[], ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ListObjectsEqualComparer
 
listPartitionAllColumnGrants(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionColumnGrantsAll(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionColumnGrantsAll(String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitionGrantsAll(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionGrantsAll(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionNames(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionNames(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitionNamesByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNamesByFilter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitionNamesPs(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNamesPs(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Lists partition names that match a given partial specification
listPartitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitions(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitions(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitions(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitions(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json description of the partitions.
listPartitions(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
List all the partitions in an hcat table.
listPartitionsByExpr(String, String, byte[], String, short, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionsByExpr(String, String, byte[], String, short, List<Partition>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get list of partitions matching specified serialized expression
listPartitionsByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get list of partitions matching specified filter
listPartitionsByFilter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get list of partitions matching specified filter
listPartitionsByFilter(String, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
List partitions by filter.
listPartitionsByFilter(String, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
listPartitionSpecs(String, String, int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionSpecs(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionSpecsByFilter(String, String, String, int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionSpecsByFilter(String, String, String, int) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionSpecsByFilter(String, String, String, int) - Method in class org.apache.hive.hcatalog.api.HCatClient
List partitions by filter, but as HCatPartitionSpecs.
listPartitionSpecsByFilter(String, String, String, int) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
listPartitionsPsWithAuth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionsPsWithAuth(String, String, List<String>, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Lists partitions that match a given partial specification and sets their auth privileges.
listPartitionsWithAuthInfo(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, List<String>, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPrincipalDBGrants(String, PrincipalType, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalDBGrants(String, PrincipalType, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalDBGrantsAll(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalDBGrantsAll(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalGlobalGrants(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalGlobalGrants(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionColumnGrants(String, PrincipalType, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionColumnGrants(String, PrincipalType, String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionColumnGrantsAll(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionColumnGrantsAll(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionGrants(String, PrincipalType, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionGrants(String, PrincipalType, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionGrantsAll(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionGrantsAll(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalTableColumnGrants(String, PrincipalType, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalTableColumnGrants(String, PrincipalType, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalTableColumnGrantsAll(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalTableColumnGrantsAll(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalTableGrantsAll(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalTableGrantsAll(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
ListResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
 
ListResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.ListResourceProcessor
 
listRoleMembers(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listRoleMembers(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Get the role to principal grant mapping for given role
listRoleNames() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listRoleNames() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list all role names
listRoleNames() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listRoleNames() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listRoles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listRoles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
 
listSize() - Method in class org.apache.hadoop.hive.common.DiskRangeList
 
listStatus(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
listStatus(JobConf) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerInputFormat
 
listStatus(JobConf, Path) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
Recursively lists status for all files starting from the directory dir
listStatusIfExists(Path, FileSystem) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
returns null if path is not exist
listStatusRecursively(FileSystem, FileStatus, List<FileStatus>) - Static method in class org.apache.hadoop.hive.common.FileUtils
Recursively lists status for all files starting from a particular directory (or individual file as base case).
listTableAllColumnGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableAllPartitionColumnGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableAllPartitionGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableColumnGrantsAll(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableColumnGrantsAll(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listTableGrantsAll(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableGrantsAll(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listTableNamesByFilter(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get a list of table names that match a filter.
listTableNamesByFilter(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a list of table names that match a filter.
listTableNamesByFilter(String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableNamesByFilter(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Gets a list of tables based on a filter string and filter type.
listTableNamesByPattern(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Returns all existing tables from the specified database which match the given pattern.
listTableNamesByPattern(String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
listTableProperties(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
List the table properties.
listTableProperties(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
List all the properties on an hcat table.
listTables(String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Return a json "show table like".
listTables(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
List all the tables in an hcat database.
listToArray() - Method in class org.apache.hadoop.hive.common.DiskRangeList
 
listType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ListTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
A List Type has homogeneous elements.
ListTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
For java serialization use only.
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(FileSystem, Path) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
Loads the table container from a folder.
load(MapJoinTableContainer[], MapJoinTableContainerSerDe[]) - Method in class org.apache.hadoop.hive.ql.exec.spark.HashTableLoader
 
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(MapJoinTableContainer[], MapJoinTableContainerSerDe[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTableLoader
 
load(String) - Method in class org.apache.hive.beeline.Commands
 
LOAD_HASHTABLE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
LOAD_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
loadClass(String) - Static method in class org.apache.hadoop.hive.common.JavaUtils
 
loadClass(String, boolean) - Static method in class org.apache.hadoop.hive.common.JavaUtils
 
loadConfig(String[]) - Method in class org.apache.hive.hcatalog.templeton.Main
 
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, boolean, long) - 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.
loader - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
loadFactor - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
loadFile(String) - Method in class org.apache.hadoop.hive.common.cli.HiveFileProcessor
load commands into buffered reader from the file
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
 
loadHashTable(ExecMapperContext, MapredContext) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
loadHashTable(ExecMapperContext, MapredContext) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
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, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
loadPartition(Path, Table, Map<String, String>, boolean, boolean, 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.
LoadPartitionDoneEvent - Class in org.apache.hadoop.hive.metastore.events
 
LoadPartitionDoneEvent(boolean, Table, Map<String, String>, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.LoadPartitionDoneEvent
 
LoadSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
LoadSemanticAnalyzer.
LoadSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
loadStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
loadTable(Path, String, boolean, boolean, boolean, 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, AcidUtils.Operation) - 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
For use with non-ACID compliant operations, such as LOAD
LoadTableDesc(Path, TableDesc, Map<String, String>, AcidUtils.Operation) - 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
For DDL operations that are not ACID compliant.
LoadTableDesc(Path, TableDesc, DynamicPartitionCtx, AcidUtils.Operation) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
localBlocksFetched - Variable in class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
Number of local blocks fetched in shuffles by tasks.
localFs - Variable in class org.apache.hadoop.fs.ProxyLocalFileSystem
 
LocalHiveSparkClient - Class in org.apache.hadoop.hive.ql.exec.spark
LocalSparkClient submit Spark job in local driver, it's responsible for build spark client environment and execute spark work.
localizeResource(Path, Path, LocalResourceType, 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
 
LocalSparkJobMonitor - Class in org.apache.hadoop.hive.ql.exec.spark.status
LocalSparkJobMonitor monitor a single Spark job status in a loop until job finished/failed/killed.
LocalSparkJobMonitor(HiveConf, SparkJobStatus) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.LocalSparkJobMonitor
 
LocalSparkJobRef - Class in org.apache.hadoop.hive.ql.exec.spark.status.impl
 
LocalSparkJobRef(String, HiveConf, LocalSparkJobStatus, JavaSparkContext) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobRef
 
LocalSparkJobStatus - Class in org.apache.hadoop.hive.ql.exec.spark.status.impl
 
LocalSparkJobStatus(JavaSparkContext, int, JobMetricsListener, SparkCounters, Set<Integer>, JavaFutureAction<Void>) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus
 
location(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc.Builder
Location.
location(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
location(String) - Method in class org.apache.hive.hcatalog.api.HCatPartition
Setter for partition directory location.
location(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for location.
location - Variable in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
location - Variable in class org.apache.hive.hcatalog.templeton.PartitionDesc
 
location - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
location - Variable in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
locatorsUpdateCopy() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
locElapsedTime(long) - Method in class org.apache.hive.beeline.BeeLine
 
lock(LockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.lock_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
lock(LockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.lock_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
lock(LockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
lock(LockRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
lock(LockRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
lock(LockRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
lock(LockRequest) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Request a set of locks.
lock(LockRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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, long) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
lock(List<HiveLockObj>, int, long) - 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
 
LOCK_ACQUIRED - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LOCK_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LOCK_SEMI_SHARED - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LOCK_SHARED - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LOCK_WAITING - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LockComponent - Class in org.apache.hadoop.hive.metastore.api
 
LockComponent() - Constructor for class org.apache.hadoop.hive.metastore.api.LockComponent
 
LockComponent(LockType, LockLevel, String) - Constructor for class org.apache.hadoop.hive.metastore.api.LockComponent
 
LockComponent(LockComponent) - Constructor for class org.apache.hadoop.hive.metastore.api.LockComponent
Performs a deep copy on other.
LockComponent._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LockComponentBuilder - Class in org.apache.hadoop.hive.metastore
A builder for LockComponents
LockComponentBuilder() - Constructor for class org.apache.hadoop.hive.metastore.LockComponentBuilder
 
lockDatabase() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
lockIdToString(long) - Static method in class org.apache.hadoop.hive.common.JavaUtils
Utility method for ACID to normalize logging info
LockLevel - Enum in org.apache.hadoop.hive.metastore.api
 
lockMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
lockNoWait(LockRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
LockRequest - Class in org.apache.hadoop.hive.metastore.api
 
LockRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.LockRequest
 
LockRequest(List<LockComponent>, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.LockRequest
 
LockRequest(LockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.LockRequest
Performs a deep copy on other.
LockRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LockRequestBuilder - Class in org.apache.hadoop.hive.metastore
Builder class to make constructing LockRequest easier.
LockRequestBuilder() - Constructor for class org.apache.hadoop.hive.metastore.LockRequestBuilder
 
LockResponse - Class in org.apache.hadoop.hive.metastore.api
 
LockResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.LockResponse
 
LockResponse(long, LockState) - Constructor for class org.apache.hadoop.hive.metastore.api.LockResponse
 
LockResponse(LockResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.LockResponse
Performs a deep copy on other.
LockResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LockState - Enum in org.apache.hadoop.hive.metastore.api
 
lockStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
LockType - Enum in org.apache.hadoop.hive.metastore.api
 
log - Static variable in class org.apache.hadoop.hive.accumulo.serde.CompositeAccumuloRowIdFactory
 
LOG - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
LOG - Static variable in class org.apache.hadoop.hive.common.ServerUtils
 
LOG - Static variable in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
LOG - Static variable in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer
 
LOG - Static variable in class org.apache.hadoop.hive.hbase.CompositeHBaseKeyFactory
 
LOG - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDeHelper
Logger
LOG - Static variable in class org.apache.hadoop.hive.metastore.events.EventCleanerTask
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.Warehouse
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.AutoProgressor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.OrcFileMergeOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.spark.HiveSparkClientFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.tez.MapRecordSource
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.tez.MergeFileRecordProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
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.merge.MergeFileMapper
 
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.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.metadata.HiveUtils
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePreFilteringRule
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
LOG - Variable in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
LOG - Variable in class org.apache.hadoop.hive.ql.optimizer.ReduceSinkMapJoinProc
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc
 
LOG - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
LOG - Variable in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
LOG - Static variable in class org.apache.hadoop.hive.ql.parse.MetaDataExportListener
 
LOG - Variable in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
LOG - Variable in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
LOG - Static variable in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
LOG - Static variable in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
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.CryptoProcessor
 
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.AuthorizationMetaStoreFilterHook
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.DummyHiveAuthorizationValidator
 
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
 
LOG - Variable in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
LOG - Static variable in class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
LOGGER
LOG - Static variable in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazyMap
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.RegexSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
LOG - Static variable in class org.apache.hive.common.util.HiveTestUtils
 
LOG - Static variable in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
LOG - Static variable in class org.apache.hive.jdbc.HiveConnection
 
LOG - Static variable in class org.apache.hive.jdbc.HiveQueryResultSet
 
LOG - Static variable in class org.apache.hive.jdbc.Utils
 
LOG - Static variable in class org.apache.hive.jdbc.ZooKeeperHiveClientHelper
 
LOG - Static variable in class org.apache.hive.service.cli.operation.Operation
 
LOG - Static variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
LOG - Static variable in class org.apache.hive.service.cli.thrift.ThriftHttpServlet
 
LOG - Static variable in class org.apache.hive.spark.client.SparkClientUtilities
 
log2(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
logCloseInfo() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
Log information to be logged at the end.
LogDivertAppender - Class in org.apache.hive.service.cli.operation
An Appender to divert logs from individual threads to the LogObject they belong to.
LogDivertAppender(OperationManager, OperationLog.LoggingLevel) - Constructor for class org.apache.hive.service.cli.operation.LogDivertAppender
 
logEveryNRows - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
logEveryNRows - Variable in class org.apache.hadoop.hive.ql.exec.MapOperator
 
logEveryNRows - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
logExceptionMessage(byte[], int, int, String) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
logExceptionMessage(ByteArrayRef, int, int, String) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
logExpr(Node, ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
logicalHashBucketCount - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
logicalHashBucketMask - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
logInfo(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
logInfo(String, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
loginFromKeytab(HiveConf) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
loginFromSpnegoKeytabAndReturnUGI(HiveConf) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
logMemoryInfo() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
Log processed row number and used memory info.
logPathToAliases() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
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.merge.MergeFileTask
 
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
 
LogRetriever - Class in org.apache.hive.hcatalog.templeton.tool
 
LogRetriever(String, LauncherDelegator.JobType, Configuration) - Constructor for class org.apache.hive.hcatalog.templeton.tool.LogRetriever
 
logSmoothing(List<HiveCalciteUtil.JoinLeafPredicateInfo>, ImmutableMap<Integer, Double>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
logStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
logUpdateMasterKey(DelegationKey) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
Synchronize master key updates / sequence generation for multiple nodes.
LogUtils - Class in org.apache.hadoop.hive.common
Utilities common to logging operations.
LogUtils() - Constructor for class org.apache.hadoop.hive.common.LogUtils
 
LogUtils.LogInitializationException - Exception in org.apache.hadoop.hive.common
 
LogUtils.LogInitializationException(String) - Constructor for exception org.apache.hadoop.hive.common.LogUtils.LogInitializationException
 
logVars(PrintStream) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
loi - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
loi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
loi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
LONG - Static variable in class org.apache.hive.hcatalog.data.DataType
 
LONG_MASK - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Mask to convert signed integer to unsigned long.
LONG_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
LONG = 4;
longArrayToRangesString(long[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
LongColAddDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColAddDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
LongColAddDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
LongColAddDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColAddDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
LongColAddDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
LongColAddLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColAddLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
LongColAddLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
LongColAddLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColAddLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
LongColAddLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
LongColDivideDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColDivideDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
LongColDivideDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
LongColDivideDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColDivideDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
LongColDivideDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
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
 
LongColEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
LongColEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
LongColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
LongColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
LongColEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
LongColEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
LongColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
LongColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
LongColGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColGreaterDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
LongColGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
LongColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColGreaterDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
LongColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
LongColGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColGreaterEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
LongColGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
LongColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColGreaterEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
LongColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
LongColGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColGreaterEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
LongColGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
LongColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColGreaterEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
LongColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
LongColGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColGreaterLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
LongColGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
LongColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColGreaterLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
LongColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
LongColLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColLessDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
LongColLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
LongColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColLessDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
LongColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
LongColLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColLessEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
LongColLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
LongColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColLessEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
LongColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
LongColLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColLessEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
LongColLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
LongColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColLessEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
LongColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
LongColLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColLessLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
LongColLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
LongColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColLessLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
LongColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
LongColModuloDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColModuloDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
LongColModuloDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
LongColModuloDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColModuloDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
LongColModuloDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
LongColModuloLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColModuloLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
LongColModuloLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
LongColModuloLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColModuloLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
LongColModuloLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
LongColMultiplyDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColMultiplyDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
LongColMultiplyDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
LongColMultiplyDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColMultiplyDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
LongColMultiplyDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
LongColMultiplyLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColMultiplyLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
LongColMultiplyLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
LongColMultiplyLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColMultiplyLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
LongColMultiplyLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
LongColNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColNotEqualDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
LongColNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
LongColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColNotEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
LongColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
LongColNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColNotEqualLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
LongColNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
LongColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongColNotEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
LongColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
LongColSubtractDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColSubtractDoubleColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
LongColSubtractDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
LongColSubtractDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColSubtractDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
LongColSubtractDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
LongColSubtractLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumn.txt, which covers binary arithmetic expressions between columns.
LongColSubtractLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
LongColSubtractLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
LongColSubtractLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalar.txt, which covers binary arithmetic expressions between a column and a scalar.
LongColSubtractLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
LongColSubtractLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
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
 
LongColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
LongColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
LongColumnStatsData(long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
LongColumnStatsData(LongColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
Performs a deep copy on other.
LongColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
LongColUnaryMinus - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnUnaryMinus.txt, which covers unary negation operator.
LongColUnaryMinus(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
LongColUnaryMinus() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
LongCompare - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Set of comparison operations over a long constant.
LongCompare() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
longIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
longIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
indices of LONG primitive keys.
longIndicesIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
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
 
LongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A LongObjectInspector inspects an Object representing a Long.
LongScalarAddDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarAddDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
LongScalarAddDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
LongScalarAddLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarAddLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
LongScalarAddLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
LongScalarDivideDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarDivideDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
LongScalarDivideDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
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
 
LongScalarEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarEqualDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
LongScalarEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
LongScalarEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarEqualLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
LongScalarEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
LongScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualTimestampColumn
 
LongScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualTimestampColumn
 
LongScalarGreaterDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarGreaterDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
LongScalarGreaterDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
LongScalarGreaterEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarGreaterEqualDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
LongScalarGreaterEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
LongScalarGreaterEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarGreaterEqualLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
LongScalarGreaterEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
LongScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarGreaterEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualTimestampColumn
 
LongScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualTimestampColumn
 
LongScalarGreaterLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarGreaterLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
LongScalarGreaterLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
LongScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarGreaterTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterTimestampColumn
 
LongScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterTimestampColumn
 
LongScalarLessDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarLessDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
LongScalarLessDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
LongScalarLessEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarLessEqualDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
LongScalarLessEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
LongScalarLessEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarLessEqualLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
LongScalarLessEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
LongScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarLessEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualTimestampColumn
 
LongScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualTimestampColumn
 
LongScalarLessLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarLessLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
LongScalarLessLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
LongScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarLessTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessTimestampColumn
 
LongScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessTimestampColumn
 
LongScalarModuloDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarModuloDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
LongScalarModuloDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
LongScalarModuloLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarModuloLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
LongScalarModuloLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
LongScalarMultiplyDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarMultiplyDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
LongScalarMultiplyDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
LongScalarMultiplyLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarMultiplyLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
LongScalarMultiplyLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
LongScalarNotEqualDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarNotEqualDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
LongScalarNotEqualDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
LongScalarNotEqualLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnCompareScalar.txt, which covers binary comparison expressions between a column and a scalar.
LongScalarNotEqualLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
LongScalarNotEqualLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
LongScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
LongScalarNotEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualTimestampColumn
 
LongScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualTimestampColumn
 
LongScalarSubtractDoubleColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarSubtractDoubleColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
LongScalarSubtractDoubleColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
LongScalarSubtractLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumn.txt.
LongScalarSubtractLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
LongScalarSubtractLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
longStats(LongColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
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
 
longToTimestamp(long, boolean) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
Converts the time in seconds or milliseconds to a timestamp.
longTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
longTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
longValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Converts this Decimal128 to a long.
longValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
longValue() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
longValue - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
longValue(long) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
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.
lookup(byte[], int, int, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMap
 
lookup(long, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
lookup(byte[], int, int, VectorMapJoinHashMapResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinBytesHashMap
 
lookup(long, VectorMapJoinHashMapResult) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashMap
 
lookup(byte[], int, int, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap
 
lookup(long, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMap
 
lookup(byte[], int, int, VectorMapJoinHashMapResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashMap
 
lookup(String) - Static method in enum org.apache.hadoop.hive.shims.HadoopShims.StoragePolicyValue
 
lookupListBucketingPaths(String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
Lookup list bucketing path.
LoopingByteArrayInputStream - Class in org.apache.hadoop.hive.conf
LoopingByteArrayInputStream.
LoopingByteArrayInputStream(byte[]) - Constructor for class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
LPAREN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
LPAREN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
lString(List<String>) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
LSTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
LZO_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
LZO = 3;

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
 
MAGIC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
main(String[]) - Static method in class org.apache.hadoop.hive.ant.GenHiveTemplate
 
main(String[]) - Static method in class org.apache.hadoop.hive.ant.GenVectorCode
 
main(String[]) - Static method in class org.apache.hadoop.hive.cli.CliDriver
 
main(String[]) - Static method in class org.apache.hadoop.hive.cli.RCFileCat
 
main(String[]) - Static method in class org.apache.hadoop.hive.contrib.mr.example.IdentityMapper
 
main(String[]) - Static method in class org.apache.hadoop.hive.contrib.mr.example.WordCountReduce
 
main(String[]) - Static method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
main(String[]) - Static method in class org.apache.hadoop.hive.hwi.HWIServer
 
main(String[]) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
main(String[]) - Static method in class org.apache.hadoop.hive.metastore.tools.HiveMetaTool
 
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.stats.PartialScanTask
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
main(String[]) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
main(String[]) - Static method in class org.apache.hive.beeline.BeeLine
Starts the program.
main(String[]) - Static method in class org.apache.hive.beeline.HiveSchemaTool
 
main(String[]) - Static method in class org.apache.hive.common.util.HiveVersionInfo
 
main(String[]) - Static method in class org.apache.hive.hcatalog.cli.HCatCli
 
main(String[]) - Static method in class org.apache.hive.hcatalog.oozie.JavaAction
 
Main - Class in org.apache.hive.hcatalog.templeton
The main executable that starts up and runs the Server.
main(String[]) - Static method in class org.apache.hive.hcatalog.templeton.Main
 
main(String[]) - Static method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
main(String[]) - Static method in class org.apache.hive.service.server.HiveServer2
 
main(String[]) - Static method in class org.apache.hive.spark.client.RemoteDriver
 
main(String[]) - Static method in class org.apache.hive.testutils.jdbc.HiveBurnInClient
 
mainWithInputRedirection(String[], InputStream) - Static method in class org.apache.hive.beeline.BeeLine
Starts the program with redirected input.
MAJOR_TYPE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
majorVersion - Variable in enum org.apache.hive.common.HiveCompat.CompatLevel
 
makeAuthFilter() - Method in class org.apache.hive.hcatalog.templeton.Main
 
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
 
makeDefaultListBucketingDirName(List<String>, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
default directory will have the same depth as number of skewed columns this will make future operation easy like DML merge, concatenate merge
makeDir(Path, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
makeDynamicPartName(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Given a dynamic partition specification, return the path corresponding to the static part of partition specification.
makeEscSpecFromName(String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makeFieldZnode(TempletonStorage.Type, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Make a ZK path to the named field.
makeFilterStringFromMap(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Given a map of partition column names to values, this creates a filter string that can be used to call the *byFilter methods
makeHar(JobContext, String, String) - Static method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
Creates a har file from the contents of a given directory, using that as root.
makeInstance(SeedObject, Set<SeedObject>) - Method in class org.apache.hadoop.hive.serde2.avro.InstanceCache
 
makeJerseyConfig() - Method in class org.apache.hive.hcatalog.templeton.Main
 
makeLauncherArgs(AppConfig, String, String, List<String>, boolean, Boolean, LauncherDelegator.JobType) - Method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
 
makeLike(VectorizedRowBatch) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Make a new (scratch) batch, which is exactly "like" the batch provided, except that it's empty
makeList(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeListBucketingDirName(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.common.FileUtils
Makes a valid list bucketing directory name.
makeMap(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeOverrideClasspath(AppConfig) - Static method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
Create the override classpath, which will be added to HADOOP_CLASSPATH at runtime by the controller job.
makePartName(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
makePartName(List<String>, List<String>, String) - Static method in class org.apache.hadoop.hive.common.FileUtils
Makes a valid partition name.
makePartName(Map<String, String>, boolean) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Makes a partition name from a specification
makePartName(List<FieldSchema>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makePartName(List<FieldSchema>, List<String>, String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Makes a valid partition name.
makePartPath(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Given a partition specification, return the path corresponding to the partition spec.
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
makePathASafeFileName(String) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Used by various tests to make sure the path is safe for Windows
makeProperties(String...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeQualified(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
makeQualified(Path, Configuration) - Static method in class org.apache.hadoop.hive.common.FileUtils
Variant of Path.makeQualified that qualifies the input path against the default file system indicated by the configuration This does not require a FileSystem handle in most cases - only requires the Filesystem URI.
makeQueryId() - Static method in class org.apache.hadoop.hive.ql.QueryPlan
 
makeSessionId() - Static method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
makeSessionId() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Get all open sessions.
makeSpecFromName(String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makeSpecFromName(Map<String, String>, Path) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makeSpecFromValues(List<FieldSchema>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makeTrackingJobZnode(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
Make a ZK path to an existing tracking node
makeTrackingZnode() - Method in class org.apache.hive.hcatalog.templeton.tool.JobStateTracker
Make a ZK path to a new tracking node
makeTransient(Class<?>, String...) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
makeValsFromName(String, AbstractList<String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Extracts values from partition name without the column names.
makeZnode(TempletonStorage.Type, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Make a ZK path to job
mAMPERSAND() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
manual(String) - Method in class org.apache.hive.beeline.Commands
 
map(InputStream, OutputStream, Mapper) - Method in class org.apache.hadoop.hive.contrib.mr.GenericMR
 
map(Reader, Writer, Mapper) - Method in class org.apache.hadoop.hive.contrib.mr.GenericMR
 
map(String[], Output) - Method in interface org.apache.hadoop.hive.contrib.mr.Mapper
Maps a single row into an intermediate rows.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileMapper
 
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.stats.PartialScanMapper
 
map(Object, RCFileValueBufferWrapper, OutputCollector<Object, Object>, Reporter) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
MAP - Static variable in class org.apache.hive.hcatalog.data.DataType
 
MAP_KEY - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
MAP_PLAN_KEY - Static variable in class org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor
 
MAP_PLAN_KEY - Static variable in class org.apache.hadoop.hive.ql.exec.tez.MergeFileRecordProcessor
 
MAP_PLAN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
MAP_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
MAP_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
MAP = 11;
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
 
mapEntry(TMapTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
MapEqualComparer - Interface in org.apache.hadoop.hive.serde2.objectinspector
 
mapIfMapAvailable(String, Function<String, String>) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Return a mapping from a given map function if available, and the key itself if not.
MapInput - Class in org.apache.hadoop.hive.ql.exec.spark
 
MapInput(SparkPlan, JavaPairRDD<WritableComparable, Writable>) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.MapInput
 
MapInput(SparkPlan, JavaPairRDD<WritableComparable, Writable>, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.MapInput
 
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
 
MapJoinBytesTableContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
Table container that serializes keys and values using LazyBinarySerDe into BytesBytesMultiHashMap, with very low memory overhead.
MapJoinBytesTableContainer(Configuration, MapJoinObjectSerDeContext, long, long) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
MapJoinBytesTableContainer(BytesBytesMultiHashMap) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
MapJoinBytesTableContainer.DirectKeyValueWriter - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinBytesTableContainer.DirectKeyValueWriter() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
MapJoinBytesTableContainer.KeyValueHelper - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
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.
MapJoinKey() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
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
 
mapJoinParentMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
MapJoinPersistableTableContainer - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
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
 
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
 
MapJoinTableContainer.ReusableGetAdaptor - Interface in org.apache.hadoop.hive.ql.exec.persistence
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures for each key.
MapJoinTableContainerDirectAccess - 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
 
mapJoinTables - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
mapJoinTables - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
mapJoinTableSerdes - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
mapJoinWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
mapJoinWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
MAPKEY_DELIM - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
mapKeysTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
mapKeysTerminatedBy(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
mapKeysTerminatedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
MAPNAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
MapObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
MapObjectInspector.
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.
MapOperator.MapOpCtx - Class in org.apache.hadoop.hive.ql.exec
 
MapOperator.MapOpCtx(String, Operator<?>, PartitionDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.MapOperator.MapOpCtx
 
mapPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
Mapper - Interface in org.apache.hadoop.hive.contrib.mr
Mapper.
MAPPER_MEMORY_MB - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
mapperMemoryMb() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
mappingSpec - Variable in class org.apache.hadoop.hive.accumulo.columns.ColumnMapping
 
mapProgress - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
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(JobConf, ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor
 
MapRecordSource - 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.
MapRecordSource() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MapRecordSource
 
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
MapredContext(boolean, JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.MapredContext
 
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) NOTE: With HIVE-9235 we removed "implements VectorizedParquetInputFormat" since all data types are not currently supported.
MapredParquetInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
 
MapredParquetInputFormat(ParquetInputFormat<ArrayWritable>) - 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, ParquetHiveRecord>) - 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
 
MAPREDUCE_JOB_TAGS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
MAPREDUCE_JOB_TAGS_ARG_PLACEHOLDER - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
MapReduceCompiler - Class in org.apache.hadoop.hive.ql.parse
 
MapReduceCompiler() - Constructor for class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
mapReduceJar(String, String, String, String, List<String>, List<String>, String, String, boolean, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.Server
Run a MapReduce Jar job.
mapReduceStreaming(List<String>, String, String, String, String, String, List<String>, String, List<String>, List<String>, List<String>, String, String, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.Server
Run a MapReduce Streaming job.
MapredWork - Class in org.apache.hadoop.hive.ql.plan
MapredWork.
MapredWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MapredWork
 
mapSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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(ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor
 
mapToClientType(String) - Method in class org.apache.hive.service.cli.operation.ClassicTableTypeMapping
 
mapToClientType(String) - Method in class org.apache.hive.service.cli.operation.HiveTableTypeMapping
 
mapToClientType(String) - Method in interface org.apache.hive.service.cli.operation.TableTypeMapping
Map hive's table type name to client's table type
mapToHiveType(String) - Method in class org.apache.hive.service.cli.operation.ClassicTableTypeMapping
 
mapToHiveType(String) - Method in class org.apache.hive.service.cli.operation.HiveTableTypeMapping
 
mapToHiveType(String) - Method in interface org.apache.hive.service.cli.operation.TableTypeMapping
Map client's table type name to hive's table type
mapToJson(Object) - Static method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Convert a map to a json string.
MapTran - Class in org.apache.hadoop.hive.ql.exec.spark
 
MapTran() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.MapTran
 
mapType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
MapTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
A Map Type has homogeneous keys and homogeneous values.
MapTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
For java serialization use only.
mapTypeNameSynonyms(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
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.conf.LoopingByteArrayInputStream
 
mark(int) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
markCleaned(CompactionInfo) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This will remove an entry from the queue after it has been compacted.
markCompacted(CompactionInfo) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This will mark an entry in the queue as compacted and put it in the ready to clean state.
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hive.hcatalog.api.HCatClient
Mark partition for event.
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
markSupported() - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
markSupported() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
match(Object, PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Chain
 
match(Object, PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Plus
 
match(Object, PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Star
 
match(Object, PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Symbol
 
match(MatchPath.SymbolFunction, Object, PTFPartition.PTFPartitionIterator<Object>) - Static method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunction
 
match(Object, PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunction
 
matchCost(TypeInfo, TypeInfo, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns -1 if passed does not match accepted.
matches(VectorExpressionDescriptor.Descriptor) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Descriptor
 
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinMergeRule
 
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinTransposeRule
 
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterProjectTransposeRule
 
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterSetOpTransposeRule
 
matches(String) - Method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay.DayOfWeek
 
matches - Variable in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunctionResult
 
matches(String) - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
matchFilesOrDir(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
MatchPath - Class in org.apache.hadoop.hive.ql.udf.ptf
return rows that meet a specified pattern.
MatchPath() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
MatchPath.Chain - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.Chain(ArrayList<MatchPath.SymbolFunction>) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Chain
 
MatchPath.MatchPathResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.MatchPathResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
 
MatchPath.Plus - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.Plus(MatchPath.SymbolFunction) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Plus
 
MatchPath.ResultExpressionParser - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.ResultExpressionParser(String, RowResolver) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExpressionParser
 
MatchPath.ResultExprInfo - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.ResultExprInfo() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExprInfo
 
MatchPath.Star - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.Star(MatchPath.SymbolFunction) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Star
 
MatchPath.Symbol - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.Symbol(ExprNodeEvaluator, ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.Symbol
 
MatchPath.SymbolFunction - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.SymbolFunction() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunction
 
MatchPath.SymbolFunctionResult - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.SymbolFunctionResult() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunctionResult
 
MatchPath.SymbolParser - Class in org.apache.hadoop.hive.ql.udf.ptf
 
MatchPath.SymbolParser(String, ArrayList<String>, ArrayList<ExprNodeEvaluator>, ArrayList<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolParser
 
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() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
max() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashTable
 
max - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
max() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
max() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMap
 
max() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMultiSet
 
max() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashSet
 
max - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
MAX_BIT_VECTORS - Static variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
MAX_BYTES - Static variable in class org.apache.hadoop.hive.serde2.io.TimestampWritable
The maximum number of bytes required for a TimestampWritable
MAX_CHAR_LENGTH - Static variable in class org.apache.hadoop.hive.common.type.HiveChar
 
MAX_DIGITS - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
Can hold up to 10^38.
MAX_INT_BD - Static variable in class org.apache.hive.common.util.DateUtils
 
MAX_POWER_FIVE_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^55 fits in 2^128.
MAX_POWER_FIVE_INT31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^13 fits in 2^31.
MAX_POWER_FIVE_INT63 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^27 fits in 2^63.
MAX_POWER_TEN_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
10^38 fits in UnsignedInt128.
MAX_POWER_TEN_INT31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
10^9 fits in 2^31.
MAX_PRECISION - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
MAX_SCALE - Static variable in class org.apache.hadoop.hive.common.type.Decimal128
Maximum value for #scale.
MAX_SCALE - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
MAX_SIZE - Variable in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
MAX_VALUE - Static variable in class org.apache.hadoop.hive.common.type.Decimal128
Maximum value that can be represented in this class.
MAX_VALUE - Static variable in class org.apache.hadoop.hive.common.type.SignedInt128
Maximum value that can be represented in this class.
MAX_VALUE - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
Maximum value that can be represented in this class.
MAX_VARCHAR_LENGTH - Static variable in class org.apache.hadoop.hive.common.type.HiveVarchar
 
maxage - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
maxage - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
MaxByteArrayOutputStream - Class in org.apache.hive.hcatalog.templeton
An output stream that will only accept the first N bytes of data.
MaxByteArrayOutputStream(int) - Constructor for class org.apache.hive.hcatalog.templeton.MaxByteArrayOutputStream
Create.
maxField - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
maxFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
maxHashTblMemory - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
Max memory usable by the hashtable before it should flush.
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
MAXIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
MAXIMUMLENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
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
 
maxLength - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyHiveChar
 
maxLength - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyHiveVarchar
 
maxLength - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveChar
 
maxLength - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryHiveVarchar
 
maxMemory - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
Total amount of memory allowed for JVM heap.
maxNextCharInd - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
maxPartitions - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
maxValue - Variable in class org.apache.hadoop.hive.ql.plan.ColStatistics.Range
 
maxWorkerThreads - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
mBETWEEN() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mBigintLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mBITWISEOR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mBITWISEXOR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mByteLengthLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mCharSetLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mCharSetName() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mCOLON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MColumnDescriptor - Class in org.apache.hadoop.hive.metastore.model
MColumnDescriptor.
MColumnDescriptor() - Constructor for class org.apache.hadoop.hive.metastore.model.MColumnDescriptor
 
MColumnDescriptor(List<MFieldSchema>) - Constructor for class org.apache.hadoop.hive.metastore.model.MColumnDescriptor
 
mCOMMA() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mCOMMENT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MDatabase - Class in org.apache.hadoop.hive.metastore.model
Storage Class representing the Hive MDatabase in a rdbms
MDatabase() - Constructor for class org.apache.hadoop.hive.metastore.model.MDatabase
Default construction to keep jpox/jdo happy
MDatabase(String, String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MDatabase
To create a database object
mDateLiteral() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mDateString() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
MDBPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MDBPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
MDBPrivilege(String, String, MDatabase, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
mDecimalLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MDelegationToken - Class in org.apache.hadoop.hive.metastore.model
 
MDelegationToken(String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MDelegationToken
 
mDigit() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mDigit() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mDIV() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mDIVIDE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mDOLLAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mDOT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MegaStruct - Class in org.apache.hadoop.hive.serde2.thrift.test
 
MegaStruct() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
MegaStruct(MegaStruct) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
Performs a deep copy on other.
MegaStruct._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
memory(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveAggregate) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveFilter) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveLimit) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveProject) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveSort) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memory(HiveUnion) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
memoryAlign() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
memoryBytesSpilled - Variable in class org.apache.hive.spark.client.metrics.Metrics
The number of in-memory bytes spilled by tasks.
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.MapredLocalTask
 
memoryMXBean - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
memorySize() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Number of bytes used by the hashmap There are two main components that take most memory: writeBuffers and refs Others include instance fields: 100
memoryThreshold - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
configure percent of memory threshold usable by QP.
MemoryTokenStore - Class in org.apache.hadoop.hive.thrift
Default in-memory token store implementation.
MemoryTokenStore() - Constructor for class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
memUsage - Variable in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
mEQUAL() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mEQUAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mEQUAL_NS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
merge(long, long) - Method in class org.apache.hadoop.hive.common.DiskRange
 
merge(UDAFExampleAvg.UDAFAvgState) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
Merge with a partial aggregation.
merge(ArrayList<String>) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
Merge with a partial aggregation.
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
merge(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
merge(IntWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
merge(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
merge(Text) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
merge(UDAFExampleMaxMinNUtil.State) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Two pointers are created to track the maximal elements in both o and MaxNArray.
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
merge(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
merge(IntWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
merge(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
merge(Text) - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
merge(ReduceSinkOperator, JoinOperator, int) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
merge(ReduceSinkOperator, ReduceSinkOperator, int) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
Current RSDedup remove/replace child RS.
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.GenericUDAFNumericStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator
 
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) - 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, DoubleObjectInspector) - 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
 
merge(BloomFilter) - Method in class org.apache.hive.common.util.BloomFilter
Merge the specified bloom filter with current bloom filter.
MERGE_PLAN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
mergeAliasedInput(String, String, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
mergeBinaryStatistics(OrcProto.BinaryStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
mergeBucketStatistics(OrcProto.BucketStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
mergeChildrenPred(Node, OpWalkerInfo, Set<String>, boolean) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
mergeCredentials(JobConf, JobConf) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
mergeCredentials(JobConf, JobConf) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
mergeCredentials(JobConf, JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
merged - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
mergeDateStatistics(OrcProto.DateStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
mergeDecimalStatistics(OrcProto.DecimalStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
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).
mergeDoubleStatistics(OrcProto.DoubleStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
mergeEstimators(NumDistinctValueEstimator) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
MergeFileInputFormat - Class in org.apache.hadoop.hive.ql.io.merge
 
MergeFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileInputFormat
 
MergeFileMapper - Class in org.apache.hadoop.hive.ql.io.merge
Mapper for fast file merging of ORC and RC files.
MergeFileMapper() - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileMapper
 
MergeFileOutputFormat - Class in org.apache.hadoop.hive.ql.io.merge
 
MergeFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileOutputFormat
 
MergeFileRecordProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Record processor for fast merging of files.
MergeFileRecordProcessor(JobConf, ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MergeFileRecordProcessor
 
MergeFileTask - Class in org.apache.hadoop.hive.ql.io.merge
Task for fast merging of ORC and RC files.
MergeFileTask() - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileTask
 
MergeFileTezProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Tez processor for fast file merging.
MergeFileTezProcessor(ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MergeFileTezProcessor
 
MergeFileWork - Class in org.apache.hadoop.hive.ql.io.merge
 
MergeFileWork(List<Path>, Path, String) - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
MergeFileWork(List<Path>, Path, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
mergeFrom(OrcProto.BinaryStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
mergeFrom(OrcProto.BloomFilter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
mergeFrom(OrcProto.BloomFilterIndex) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
mergeFrom(OrcProto.BucketStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
mergeFrom(OrcProto.ColumnEncoding) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
mergeFrom(OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
mergeFrom(OrcProto.DateStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
mergeFrom(OrcProto.DecimalStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
mergeFrom(OrcProto.DoubleStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
mergeFrom(OrcProto.Footer) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
mergeFrom(OrcProto.IntegerStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
mergeFrom(OrcProto.Metadata) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
mergeFrom(OrcProto.PostScript) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
mergeFrom(OrcProto.RowIndex) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
mergeFrom(OrcProto.RowIndexEntry) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
mergeFrom(OrcProto.Stream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
mergeFrom(OrcProto.StringStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
mergeFrom(OrcProto.StripeFooter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
mergeFrom(OrcProto.StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
mergeFrom(OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
mergeFrom(OrcProto.TimestampStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
mergeFrom(OrcProto.Type) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
mergeFrom(OrcProto.UserMetadataItem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
 
mergeIntStatistics(OrcProto.IntegerStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
mergeJoinDummyVertexs - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
MergeJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
MergeJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MergeJoinProc
 
MergeJoinWork - Class in org.apache.hadoop.hive.ql.plan
 
MergeJoinWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
mergeOp - Variable in class org.apache.hadoop.hive.ql.exec.tez.MergeFileRecordProcessor
 
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.
mergeStatistics(OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
mergeStringStatistics(OrcProto.StringStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
mergeTimestampStatistics(OrcProto.TimestampStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
mergeTokenIntoJobConf(JobConf, Token<?>) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Merge the provided Token into the JobConf.
mergeUniqElems(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
mergeWithChildrenPred(Node, OpWalkerInfo, ExprWalkerInfo, Set<String>) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
Take current operators pushdown predicates and merges them with children's pushdown predicates.
mergingInto(MapWork) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
MessageDeserializer - Class in org.apache.hive.hcatalog.messaging
Interface for converting HCat events from String-form back to HCatEventMessage instances.
MessageDeserializer() - Constructor for class org.apache.hive.hcatalog.messaging.MessageDeserializer
 
messageFactory - Static variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
MessageFactory - Class in org.apache.hive.hcatalog.messaging
Abstract Factory for the construction of HCatalog message instances.
MessageFactory() - Constructor for class org.apache.hive.hcatalog.messaging.MessageFactory
 
MessagingUtils - Class in org.apache.hive.hcatalog.messaging.jms
Helper Utility to assist consumers of HCat Messages in extracting message-content from JMS messages.
META_TABLE_COLUMN_TYPES - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_COLUMNS - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_DB - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_LOCATION - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_NAME - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
META_TABLE_PARTITION_COLUMN_TYPES - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_PARTITION_COLUMNS - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_SERDE - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
META_TABLE_STORAGE - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
METACONF_PREFIX - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
metaConfVars - Static variable in class org.apache.hadoop.hive.conf.HiveConf
User configurable Metastore vars
Metadata - Class in org.apache.hadoop.hive.ql.io.orc
 
metadata() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
 
metadata() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
metadata(String) - Method in class org.apache.hive.beeline.Commands
 
metadata(String, String[]) - Method in class org.apache.hive.beeline.Commands
 
METADATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
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.
METADATALENGTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
MetadataListStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
StructObjectInspector works on struct data that is stored as a Java List or Java Array object.
MetadataListStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
MetadataListStructObjectInspector(List<String>, List<String>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.AggrStats
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Database
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Date
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Decimal
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Function
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.LockComponent
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.LockRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.LockResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.MetaException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Order
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Role
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Schema
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Type
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Version
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Graph
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Operator
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Query
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Stage
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Task
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde.test.InnerStruct
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.service.HiveServerException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TBoolColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TBoolValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TByteColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TByteValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TColumnDesc
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TColumnValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TDoubleValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI16Column
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI16Value
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI32Column
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI32Value
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI64Column
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TI64Value
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TOperationHandle
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TRow
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TRowSet
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TSessionHandle
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TStatus
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TStringColumn
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TStringValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TTableSchema
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TTypeDesc
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
metaDataMap - Static variable in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
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
 
MetadataOperation - Class in org.apache.hive.service.cli.operation
MetadataOperation.
MetadataOperation(HiveSession, OperationType) - Constructor for class org.apache.hive.service.cli.operation.MetadataOperation
 
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.
MetadataReader - Class in org.apache.hadoop.hive.ql.io.orc
 
MetadataReader(FileSystem, Path, CompressionCodec, int, int) - Constructor for class org.apache.hadoop.hive.ql.io.orc.MetadataReader
 
MetadataReader(FSDataInputStream, CompressionCodec, int, int) - Constructor for class org.apache.hadoop.hive.ql.io.orc.MetadataReader
 
MetadataTypedColumnsetSerDe - Class in org.apache.hadoop.hive.serde2
MetadataTypedColumnsetSerDe.
MetadataTypedColumnsetSerDe() - Constructor for class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
MetaException - Exception in org.apache.hadoop.hive.metastore.api
 
MetaException() - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
 
MetaException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
 
MetaException(MetaException) - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
Performs a deep copy on other.
MetaException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaStoreAuthzAPIAuthorizerEmbedOnly - Class in org.apache.hadoop.hive.ql.security.authorization
If this authorizer is used, it allows authorization api to be invoked only in embedded metastore mode.
MetaStoreAuthzAPIAuthorizerEmbedOnly() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
metastoreCheck() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
MetaStoreEndFunctionContext - Class in org.apache.hadoop.hive.metastore
Base class which provides context to implementations of MetaStoreEndFunctionListener
MetaStoreEndFunctionContext(boolean, Exception, String) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionContext
 
MetaStoreEndFunctionContext(boolean) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionContext
 
MetaStoreEndFunctionListener - Class in org.apache.hadoop.hive.metastore
This abstract class needs to be extended to provide implementation of actions that need to be performed when a function ends.
MetaStoreEndFunctionListener(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionListener
 
MetaStoreEventListener - Class in org.apache.hadoop.hive.metastore
This abstract class needs to be extended to provide implementation of actions that needs to be performed when a particular event occurs on a metastore.
MetaStoreEventListener(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
MetaStoreFilterHook - Interface in org.apache.hadoop.hive.metastore
Metadata filter hook for metastore client.
MetaStoreFS - Interface in org.apache.hadoop.hive.metastore
Define a set of APIs that may vary in different environments
MetaStoreInit - Class in org.apache.hadoop.hive.metastore
MetaStoreInit defines functions to init/update MetaStore connection url.
MetaStoreInit() - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreInit
 
MetaStoreInitContext - Class in org.apache.hadoop.hive.metastore
Base class which provides context to implementations of MetaStoreInitListener
MetaStoreInitContext() - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreInitContext
 
MetaStoreInitListener - Class in org.apache.hadoop.hive.metastore
This abstract class needs to be extended to provide implementation of actions that needs to be performed when HMSHandler is initialized
MetaStoreInitListener(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreInitListener
 
MetaStorePreEventListener - Class in org.apache.hadoop.hive.metastore
This abstract class needs to be extended to provide implementation of actions that needs to be performed before a particular event occurs on a metastore.
MetaStorePreEventListener(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.MetaStorePreEventListener
 
MetaStoreSchemaInfo - Class in org.apache.hadoop.hive.metastore
 
MetaStoreSchemaInfo(String, HiveConf, String) - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo
 
MetaStoreThread - Interface in org.apache.hadoop.hive.metastore
A thread that runs in the metastore, separate from the threads in the thrift service.
metaStoreUri - Variable in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
MetaStoreUtils - Class in org.apache.hadoop.hive.metastore
 
MetaStoreUtils() - Constructor for class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
metaVars - Static variable in class org.apache.hadoop.hive.conf.HiveConf
Metastore related options that the db is initialized against.
metricExpands - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
metricPutConflict - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
Metrics - Class in org.apache.hadoop.hive.common.metrics
Metrics Subsystem - allows exposure of a number of named parameters/counters via jmx, intended to be used as a static subsystem Has a couple of primary ways it can be used: (i) Using the set and get methods to set and get named parameters (ii) Using the incrementCounter method to increment and set named parameters in one go, rather than having to make a get and then a set.
Metrics - Class in org.apache.hive.spark.client.metrics
Metrics tracked during the execution of a job.
Metrics(long, long, long, long, long, long, long, InputMetrics, ShuffleReadMetrics, ShuffleWriteMetrics) - Constructor for class org.apache.hive.spark.client.metrics.Metrics
 
Metrics(TaskMetrics) - Constructor for class org.apache.hive.spark.client.metrics.Metrics
 
Metrics.MetricsScope - Class in org.apache.hadoop.hive.common.metrics
MetricsScope : A class that encapsulates an idea of a metered scope.
MetricsCollection - Class in org.apache.hive.spark.client
Provides metrics collected for a submitted job.
MetricsCollection() - Constructor for class org.apache.hive.spark.client.MetricsCollection
 
MetricsMBean - Interface in org.apache.hadoop.hive.common.metrics
MBean definition for metrics tracking from jmx
MetricsMBeanImpl - Class in org.apache.hadoop.hive.common.metrics
 
MetricsMBeanImpl() - Constructor for class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
mExponent() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MFieldSchema - Class in org.apache.hadoop.hive.metastore.model
Represent a column or a type of a table or object
MFieldSchema() - Constructor for class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
MFieldSchema(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
MFunction - Class in org.apache.hadoop.hive.metastore.model
 
MFunction() - Constructor for class org.apache.hadoop.hive.metastore.model.MFunction
 
MFunction(String, MDatabase, String, String, String, int, int, List<MResourceUri>) - Constructor for class org.apache.hadoop.hive.metastore.model.MFunction
 
MGlobalPrivilege - Class in org.apache.hadoop.hive.metastore.model
User global level privileges
MGlobalPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
MGlobalPrivilege(String, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
mGREATERTHAN() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mGREATERTHAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mGREATERTHANOREQUALTO() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mGREATERTHANOREQUALTO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mHexDigit() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mIdentifier() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
midTreeNode(ExpressionTree.TreeNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
millisecondsLongToTimestamp(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
millisFormatString - Static variable in class org.apache.hive.common.util.TimestampParser
 
millisToDays(long) - Static method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
min() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
min() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashTable
 
min - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
min() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
min() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMap
 
min() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMultiSet
 
min() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashSet
 
min - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
MIN_SCALE - Static variable in class org.apache.hadoop.hive.common.type.Decimal128
Minimum value for #scale.
MIN_VALUE - Static variable in class org.apache.hadoop.hive.common.type.Decimal128
Minimum value that can be represented in this class.
MIN_VALUE - Static variable in class org.apache.hadoop.hive.common.type.SignedInt128
Minimum value that can be represented in this class.
MIN_VALUE - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
Minimum value that can be represented in this class.
MIndex - Class in org.apache.hadoop.hive.metastore.model
Represents hive's index definition.
MIndex() - Constructor for class org.apache.hadoop.hive.metastore.model.MIndex
 
MIndex(String, MTable, int, int, Map<String, String>, MTable, MStorageDescriptor, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MIndex
 
minField - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
minFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
MINIMUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
minimumTransactionId(long) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
The minimum transaction id that is included in this file.
MiniSparkOnYARNCluster - Class in org.apache.hadoop.hive.shims
This should be a very thin wrapper of MiniYARNCluster, which helps to build a embedded YARN cluster for Spark.
MiniSparkOnYARNCluster(String) - Constructor for class org.apache.hadoop.hive.shims.MiniSparkOnYARNCluster
 
MiniSparkOnYARNCluster(String, int, int) - Constructor for class org.apache.hadoop.hive.shims.MiniSparkOnYARNCluster
 
MiniSparkOnYARNCluster(String, int, int, int, int) - Constructor for class org.apache.hadoop.hive.shims.MiniSparkOnYARNCluster
 
MiniStruct - Class in org.apache.hadoop.hive.serde2.thrift.test
 
MiniStruct() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
MiniStruct(MiniStruct) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
Performs a deep copy on other.
MiniStruct._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
minMaxEnabled() - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
MINOR_TYPE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
minorVersion - Variable in enum org.apache.hive.common.HiveCompat.CompatLevel
 
mIntegralLiteral() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
minus(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
minusOpType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
minValue - Variable in class org.apache.hadoop.hive.ql.plan.ColStatistics.Range
 
minWorkerThreads - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
mkdir(FileSystem, Path, boolean, Configuration) - Static method in class org.apache.hadoop.hive.common.FileUtils
Creates the directory and all necessary parent directories.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
mkdirs(Path, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
mKW_ADD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ADMIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AFTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ALL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ALTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ANALYZE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AND() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mKW_AND() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ARCHIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ARRAY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ASC() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AUTHORIZATION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BEFORE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BETWEEN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BIGINT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BINARY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BOOLEAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BOTH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BUCKET() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BUCKETS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_BY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CASCADE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CASE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CAST() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CHANGE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CHAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTERED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTERSTATUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLLECTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLUMN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLUMNS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMMENT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMPACT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMPACTIONS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMPUTE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CONCATENATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CONF() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CONTINUE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CREATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CROSS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CUBE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CURRENT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CURRENT_DATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CURRENT_TIMESTAMP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CURSOR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATA() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATABASE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATABASES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATE() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mKW_DATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATETIME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DAY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DBPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DECIMAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DEFERRED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DEFINED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DELETE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DELIMITED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DEPENDENCY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DESC() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DESCRIBE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DIRECTORIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DIRECTORY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DISABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DISTINCT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DISTRIBUTE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DOUBLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DROP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ELEM_TYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ELSE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ENABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_END() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ESCAPED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXCHANGE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXCLUSIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXISTS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXPLAIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXPORT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXTENDED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXTERNAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FALSE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FETCH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FIELDS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FILE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FILEFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FIRST() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FLOAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FOLLOWING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FOR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FORMATTED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FROM() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FULL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FUNCTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FUNCTIONS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_GRANT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_GROUP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_GROUPING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_HAVING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_HOLD_DDLTIME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_HOUR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IDXPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IF() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IGNORE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IMPORT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INDEX() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INDEXES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INNER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPATH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPUTDRIVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPUTFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INSERT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INTERSECT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INTERVAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INTO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ITEMS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_JAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_JOIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_KEY_TYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_KEYS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LATERAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LEFT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LESS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LIKE() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mKW_LIKE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LIMIT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LINES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOAD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOCAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOCATION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOCKS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LOGICAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_LONG() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MACRO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MAP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MAPJOIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MATERIALIZED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_METADATA() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MINUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MINUTE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MONTH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MORE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MSCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_NO_DROP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_NONE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_NOSCAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_NOT() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mKW_NOT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_NULL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OF() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OFFLINE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OPTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OR() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mKW_OR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ORDER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTPUTDRIVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTPUTFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OVERWRITE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OWNER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PARTIALSCAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PARTITION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PARTITIONED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PARTITIONS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PERCENT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PLUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PRECEDING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PRESERVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PRETTY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PRINCIPALS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PROCEDURE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PROTECTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PURGE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RANGE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READ() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READONLY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REBUILD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RECORDREADER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RECORDWRITER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REDUCE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REGEXP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RELOAD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RENAME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPAIR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPLACE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPLICATION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RESTRICT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REVOKE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REWRITE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RIGHT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RLIKE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ROLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ROLES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ROLLUP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ROW() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ROWS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SCHEMA() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SCHEMAS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SECOND() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SELECT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SEMI() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SERDE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SERDEPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SERVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SET() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SETS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHARED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHOW() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHOW_DATABASE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SKEWED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SMALLINT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SORT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SORTED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SSL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STATISTICS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STORED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STREAMTABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STRING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STRUCT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLESAMPLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TBLPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TEMPORARY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TERMINATED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_THEN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TIMESTAMP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TINYINT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TOUCH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TRANSACTIONS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TRANSFORM() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TRIGGER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TRUE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TRUNCATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNARCHIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNBOUNDED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNDO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNIONTYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNIQUEJOIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNLOCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNSET() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNSIGNED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UPDATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_URI() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_USE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_USER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_USING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UTC() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UTCTIMESTAMP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_VALUE_TYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_VALUES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_VARCHAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_VIEW() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_WHEN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_WHERE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_WHILE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_WINDOW() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_WITH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_YEAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLCURLY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLESSTHAN() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mLESSTHAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLESSTHANOREQUALTO() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mLESSTHANOREQUALTO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLetter() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mLetter() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLPAREN() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mLPAREN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLSQUARE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MMasterKey - Class in org.apache.hadoop.hive.metastore.model
 
MMasterKey(int, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MMasterKey
 
MMasterKey(String) - Constructor for class org.apache.hadoop.hive.metastore.model.MMasterKey
 
MMasterKey(int) - Constructor for class org.apache.hadoop.hive.metastore.model.MMasterKey
 
mMINUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mMOD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mNOTEQUAL() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mNOTEQUAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MNotificationLog - Class in org.apache.hadoop.hive.metastore.model
 
MNotificationLog() - Constructor for class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
MNotificationLog(int, String, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
MNotificationNextId - Class in org.apache.hadoop.hive.metastore.model
 
MNotificationNextId() - Constructor for class org.apache.hadoop.hive.metastore.model.MNotificationNextId
 
MNotificationNextId(long) - Constructor for class org.apache.hadoop.hive.metastore.model.MNotificationNextId
 
mNumber() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
modify(EnumSet<CompressionCodec.Modifier>) - Method in interface org.apache.hadoop.hive.ql.io.orc.CompressionCodec
Produce a modified compression codec if the underlying algorithm allows modification.
modulo(Decimal128, Decimal128, Decimal128, short) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Performs decimal modulo
moduloChecked(int, HiveDecimal, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
moduloChecked(int, HiveDecimalWritable, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
moduloChecked(int, HiveDecimalWritable, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
moduloChecked(int, HiveDecimal, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
moduloNum - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
monitor(JavaFutureAction<T>, SparkCounters, Set<Integer>) - Method in interface org.apache.hive.spark.client.JobContext
Monitor a job.
monitorExecution(DAGClient, HiveTxnManager, HiveConf, DAG) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
monitorExecution handles status printing, failures during execution and final status retrieval.
monitorJob() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobRef
 
monitorJob() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobRef
 
monitorJob() - Method in interface org.apache.hadoop.hive.ql.exec.spark.status.SparkJobRef
 
MONTHS_PER_YEAR - Static variable in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
MOrder - Class in org.apache.hadoop.hive.metastore.model
 
MOrder(String, int) - Constructor for class org.apache.hadoop.hive.metastore.model.MOrder
 
movedParts - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
List of inserted partitions
moveFile(HiveConf, Path, Path, FileSystem, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
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
 
moveTask - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
moveToAppropriateTrash(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
moveToAppropriateTrash(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
moveToAppropriateTrash(FileSystem, Path, Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Move the directory/file to trash.
moveToAppropriateTrash(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
moveToCurrentRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
moveToInsertRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
moveToTrash(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hive.common.FileUtils
Move a particular file or directory to the trash.
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, boolean) - 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
 
MPartition - Class in org.apache.hadoop.hive.metastore.model
 
MPartition() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartition
 
MPartition(String, MTable, List<String>, int, int, MStorageDescriptor, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartition
 
MPartitionColumnPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MPartitionColumnPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
MPartitionColumnPrivilege(String, String, MPartition, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
MPartitionColumnStatistics - Class in org.apache.hadoop.hive.metastore.model
MPartitionColumnStatistics - Represents Hive's partiton level Column Statistics Description.
MPartitionColumnStatistics() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
MPartitionEvent - Class in org.apache.hadoop.hive.metastore.model
 
MPartitionEvent(String, String, String, int) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
MPartitionEvent() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
MPartitionPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MPartitionPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
MPartitionPrivilege(String, String, MPartition, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
mPLUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MPrincipalDesc - Class in org.apache.hadoop.hive.metastore.model
 
MPrincipalDesc() - Constructor for class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
MPrincipalDesc(String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
mQUESTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mQuotedIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MR_AM_MEMORY_MB - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
MR_SHUFFLE_SORT - Static variable in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
mRCURLY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRegexComponent() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MResourceUri - Class in org.apache.hadoop.hive.metastore.model
 
MResourceUri() - Constructor for class org.apache.hadoop.hive.metastore.model.MResourceUri
 
MResourceUri(int, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MResourceUri
 
MRole - Class in org.apache.hadoop.hive.metastore.model
 
MRole() - Constructor for class org.apache.hadoop.hive.metastore.model.MRole
 
MRole(String, int, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MRole
 
MRoleMap - Class in org.apache.hadoop.hive.metastore.model
 
MRoleMap() - Constructor for class org.apache.hadoop.hive.metastore.model.MRoleMap
 
MRoleMap(String, String, MRole, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MRoleMap
 
mRPAREN() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mRPAREN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRSQUARE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mrwork - Variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
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.
mSEMICOLON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MSerDeInfo - Class in org.apache.hadoop.hive.metastore.model
 
MSerDeInfo(String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
msg - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
mSmallintLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mSTAR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MStorageDescriptor - Class in org.apache.hadoop.hive.metastore.model
 
MStorageDescriptor() - Constructor for class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
MStorageDescriptor(MColumnDescriptor, String, String, String, boolean, int, MSerDeInfo, List<String>, List<MOrder>, Map<String, String>, List<String>, List<MStringList>, Map<MStringList, String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
MStringList - Class in org.apache.hadoop.hive.metastore.model
It represents data structure of string list.
MStringList(List<String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MStringList
 
mStringLiteral() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mStringLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MTable - Class in org.apache.hadoop.hive.metastore.model
 
MTable() - Constructor for class org.apache.hadoop.hive.metastore.model.MTable
 
MTable(String, MDatabase, MStorageDescriptor, String, int, int, int, List<MFieldSchema>, Map<String, String>, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MTable
 
MTableColumnPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MTableColumnPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
MTableColumnPrivilege(String, String, MTable, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
MTableColumnStatistics - Class in org.apache.hadoop.hive.metastore.model
MTableColumnStatistics - Represents Hive's Column Statistics Description.
MTableColumnStatistics() - Constructor for class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
MTablePrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MTablePrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
MTablePrivilege(String, String, MTable, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
mTILDE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mTinyintLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mTokens() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mTokens() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MType - Class in org.apache.hadoop.hive.metastore.model
Represents a Hive type
MType(String, String, String, List<MFieldSchema>) - Constructor for class org.apache.hadoop.hive.metastore.model.MType
 
MType() - Constructor for class org.apache.hadoop.hive.metastore.model.MType
 
MultiDelimitSerDe - Class in org.apache.hadoop.hive.contrib.serde2
This SerDe allows user to use multiple characters as the field delimiter for a table.
MultiDelimitSerDe() - Constructor for class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
multiFileSpray - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
MultiOutputFormat - Class in org.apache.hive.hcatalog.mapreduce
The MultiOutputFormat class simplifies writing output data to multiple outputs.
MultiOutputFormat() - Constructor for class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
 
MultiOutputFormat.JobConfigurer - Class in org.apache.hive.hcatalog.mapreduce
Class that supports configuration of the job for multiple output formats.
MultiOutputFormat.MultiOutputCommitter - Class in org.apache.hive.hcatalog.mapreduce
 
MultiOutputFormat.MultiOutputCommitter(TaskAttemptContext) - Constructor for class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
multiply(Decimal128, Decimal128, Decimal128, short) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Calculates multiplication and puts the result into the given object.
multiply(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
multiply(SignedInt128, SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
Calculates multiplication and puts the result into the given object.
multiplyBy(double) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
multiplyChecked(int, HiveDecimal, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
multiplyChecked(int, HiveDecimalWritable, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
multiplyChecked(int, HiveDecimalWritable, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
multiplyChecked(int, HiveDecimal, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
multiplyConstructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
multiplyConstructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
multiplyConstructive256(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result of multiplication as 256bit data.
multiplyDestructive(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Performs multiplication, changing the scale of this object to the specified value.
multiplyDestructive(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Performs multiplication.
multiplyDestructive(int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Performs multiplication.
multiplyDestructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Multiplies this value with the given integer value.
multiplyDestructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Multiplies this value with the given value.
multiplyDestructiveNativeDecimal128(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
As of 2/11/2014 this has a known bug in multiplication.
multiplyScaleDownTenDestructive(UnsignedInt128, short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Multiply this value with the given value, followed by ten-based scale down.
multiplyShiftDestructive(UnsignedInt128, short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Multiplies this value with the given value, followed by right bit shifts to scale it back to this object.
Murmur3 - Class in org.apache.hive.common.util
Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms.
Murmur3() - Constructor for class org.apache.hive.common.util.Murmur3
 
murmurHash(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.DatePersistenceDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
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
 
MuxOperator.Handler - Class in org.apache.hadoop.hive.ql.exec
Handler is used to construct the key-value structure.
MuxOperator.Handler(ObjectInspector, List<ExprNodeDesc>, List<ExprNodeDesc>, List<String>, List<String>, Integer) - Constructor for class org.apache.hadoop.hive.ql.exec.MuxOperator.Handler
 
MVersionTable - Class in org.apache.hadoop.hive.metastore.model
 
MVersionTable() - Constructor for class org.apache.hadoop.hive.metastore.model.MVersionTable
 
MVersionTable(String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MVersionTable
 
mvFileToFinalPath(Path, Configuration, boolean, Log, DynamicPartitionCtx, FileSinkDesc, Reporter) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
mWS() - Method in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
mWS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
myAuthority - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 
MyEnum - Enum in org.apache.hadoop.hive.serde2.thrift.test
 
MYINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
myScheme - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 
MYSTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
myUri - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 

N

name - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
name - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
name - Variable in class org.apache.hadoop.hive.ql.io.orc.InStream
 
name - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
name - Variable in class org.apache.hive.hcatalog.templeton.ColumnDesc
 
name - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.SerdeDesc
 
name - Variable in class org.apache.hive.hcatalog.templeton.TablePropertyDesc
 
name() - Method in class org.apache.hive.spark.client.rpc.RpcDispatcher
Override this to add a name to the dispatcher, for debugging purposes.
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
NAMED - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
names(List<String>) - Static method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
Namespace() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
nanos - Variable in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
nanos - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TimestampTreeReader
 
NANOS_PER_SEC - Static variable in class org.apache.hive.common.util.DateUtils
 
NANOS_PER_SEC_BD - Static variable in class org.apache.hive.common.util.DateUtils
 
nanosResult - Variable in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
NanoTime - Class in org.apache.hadoop.hive.ql.io.parquet.timestamp
Provides a wrapper representing a parquet-timestamp, with methods to convert to and from binary.
NanoTime(int, long) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
NanoTimeUtils - Class in org.apache.hadoop.hive.ql.io.parquet.timestamp
Utilities for converting from java.sql.Timestamp to parquet timestamp.
NanoTimeUtils() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTimeUtils
 
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
 
nativesql(String) - Method in class org.apache.hive.beeline.Commands
 
nativeSQL(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
nbins - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
ndvField - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
ndvFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
needCommonSetup - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
needHashTableSetup - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
needsLock() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
needsQuotedIdentifier() - Method in interface org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser
Does the DB required table/column names quoted
needsQuotedIdentifier() - Method in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.AddPartitionReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterPartitionReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.AlterTableReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.CreateTableReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropDatabaseReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropPartitionReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.DropTableReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.exim.InsertReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.NoopReplicationTask
 
needsStagingDirs() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Returns true if the replication task in question needs to create staging directories to complete its operation.
needsTagging(ReduceWork) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
needUploadToHDFS(URI, SparkConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
negate() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
negate() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
negate() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
negate(SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
negate(int, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
negate(int, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
negateDestructive() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Reverses the sign of this Decimal128.
negateDestructive() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Reverses the sign of this object.
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Gets the negative function of the current one.
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
negative() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
NEGATIVE_INT_MASK - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Mask to convert an int to a negative int.
NEGATIVE_LONG_MASK - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
Mask to convert a long to a negative long.
NEGOTIATE - Static variable in class org.apache.hive.service.auth.HttpAuthUtils
 
newAggregations() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
newBatch(Long, Long) - Method in interface org.apache.hive.hcatalog.streaming.RecordWriter
Acquire a new RecordUpdater.
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
newBuilder(OrcProto.BinaryStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
newBuilder(OrcProto.BloomFilter) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
newBuilder(OrcProto.BloomFilterIndex) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
newBuilder(OrcProto.BucketStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
newBuilder(OrcProto.ColumnEncoding) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
newBuilder(OrcProto.ColumnStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
newBuilder(OrcProto.DateStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
newBuilder(OrcProto.DecimalStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
newBuilder(OrcProto.DoubleStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
newBuilder(OrcProto.Footer) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
newBuilder(OrcProto.IntegerStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
newBuilder(OrcProto.Metadata) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
newBuilder(OrcProto.PostScript) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
newBuilder(OrcProto.RowIndex) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
newBuilder(OrcProto.RowIndexEntry) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
newBuilder(OrcProto.Stream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
newBuilder(OrcProto.StringStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
newBuilder(OrcProto.StripeFooter) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
newBuilder(OrcProto.StripeInformation) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
newBuilder(OrcProto.StripeStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
newBuilder(OrcProto.TimestampStatistics) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
newBuilder(OrcProto.Type) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
newBuilder(OrcProto.UserMetadataItem) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
newBuilder() - Static method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
newBuilderForType() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
newConnection(boolean) - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
Acquire a new connection to MetaStore for streaming
newConnection(boolean, HiveConf) - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
Acquire a new connection to MetaStore for streaming
newConnection(boolean, HiveConf, UserGroupInformation) - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
Acquire a new connection to MetaStore for streaming.
newExecuteStatementOperation(HiveSession, String, Map<String, String>, boolean) - Static method in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
newExecuteStatementOperation(HiveSession, String, Map<String, String>, boolean) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
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).
newGetCatalogsOperation(HiveSession) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetColumnsOperation(HiveSession, String, String, String, String) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetFunctionsOperation(HiveSession, String, String, String) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetSchemasOperation(HiveSession, String, String) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetTablesOperation(HiveSession, String, String, String, List<String>) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetTableTypesOperation(HiveSession) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newGetTypeInfoOperation(HiveSession) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
newInstance(Class<T>, Class<?>[], Object[]) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Create an object of the given class.
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
 
newInstance(Class<T>, Configuration) - Static method in class org.apache.hive.common.util.ReflectionUtil
Create an object for the given class and initialize it from conf
newJobContext(Job) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
newJobContext(Job) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
newJobContext(Job) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
newJobContext(Job) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
newKeys - Variable in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
newLineCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
newPrimitiveColumnDescriptor(String, String, Type, int) - Static method in class org.apache.hive.service.cli.ColumnDescriptor
 
newRetryingHMSHandler(IHMSHandler, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
newRetryingHMSHandler(IHMSHandler, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
newRetryingHMSHandler(String, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
newSynchronizedClient(IMetaStoreClient) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Creates a synchronized wrapper for any IMetaStoreClient.
newTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
newTable - Variable in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
newTaskAttemptContext(Configuration, Progressable) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
newTaskAttemptContext(Configuration, Progressable) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
newTaskAttemptContext(Configuration, Progressable) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
newTaskAttemptContext(Configuration, Progressable) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
newTaskAttemptID(JobID, boolean, int, int) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
newTaskAttemptID(JobID, boolean, int, int) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
newTaskAttemptID(JobID, boolean, int, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
newThread(Runnable) - Method in class org.apache.hive.service.server.ThreadFactoryWithGarbageCleanup
 
newToken(int) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.Token
Returns a new Token object, by default.
next(Text, AccumuloHiveRow) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloRecordReader
 
next - Variable in class org.apache.hadoop.hive.common.DiskRangeList
 
next(LongWritable, BytesWritable) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextInputFormat.Base64LineRecordReader
 
next(Writable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordReader
 
next() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
next() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
next() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
next() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
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.BytesBytesMultiHashMap.Result
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
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.persistence.UnwrapRowContainer
 
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() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList.ResultIterator
 
next(Writable) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
next() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger
 
next() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.KeyValuesInputMerger
 
next() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
next() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
next() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
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
Deprecated.
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(OrcFileKeyWrapper, OrcFileValueWrapper) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
next(NullWritable, OrcStruct) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat.NullKeyRecordReader
 
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(LongWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
next(NullWritable, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
next(LongWritable) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
next(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
next(HiveConf, SemanticAnalyzer, UnparseTranslator, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.WindowingComponentizer
 
next() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingIterator
 
next - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
A reference to the next regular (non-special) token from the input stream.
next(K, V) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
next() - Method in class org.apache.hive.beeline.IncrementalRows
 
next() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec.HCatPartitionIterator
 
next() - Method in class org.apache.hive.hcatalog.api.repl.HCatReplicationTaskIterator
 
next() - Method in class org.apache.hive.jdbc.HiveQueryResultSet
Moves the cursor down one row from its current position.
nextBatch(VectorizedRowBatch) - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Read the next row batch.
nextBlock(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
nextBlock(RCFileKeyBufferWrapper, RCFileValueBufferWrapper) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
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.
nextDay(Date, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNextDay
 
nextKeyBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
nextKeyValue() - Method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
nextKeyValue() - Method in class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
nextOutputRow() - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
nextRank(GenericUDAFRank.RankBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFDenseRank.GenericUDAFDenseRankEvaluator
 
nextRank(GenericUDAFRank.RankBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFAbstractRankEvaluator
 
nextRow - Variable in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolFunctionResult
 
nextStripe(OrcFileKeyWrapper, OrcFileValueWrapper) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BinaryTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BooleanTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ByteTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.CharTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DateTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DecimalTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DoubleTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.FloatTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.IntTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ListTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.LongTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.MapTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ShortTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDictionaryTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDirectTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StructTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TimestampTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
Populates the isNull vector array in the previousVector object based on the present stream values.
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.UnionTreeReader
 
nextVector(Object, long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.VarcharTreeReader
 
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_CURRENT_TXN - Static variable in class org.apache.hadoop.hive.ql.session.SessionState
When SessionState.setCurrentTxn(long) is set to this or SessionState.getCurrentTxn()} returns this it indicates that there is not a current transaction in this session.
NO_DIFF - Static variable in class org.apache.hive.hcatalog.api.HCatTable
2 HCatTables are considered equivalent if lhs.diff(rhs).equals(NO_DIFF) == true;
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.
Node - Interface in org.apache.hadoop.hive.serde2.dynamic_type
 
nodeArity() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
nodeCreated() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
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.
NodeType - Enum in org.apache.hadoop.hive.ql.plan.api
 
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
 
noDrop - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
noDropCascade - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
noLockNeeded() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
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.
noMatchs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
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
 
NONE_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
NONE = 0;
nonNullByte - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
nonReserved() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
nonReserved() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
nonSpills - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
NonSyncByteArrayInputStream - Class in org.apache.hadoop.hive.common.io
A thread-not-safe version of ByteArrayInputStream, which removes all synchronized modifiers.
NonSyncByteArrayInputStream() - Constructor for class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
NonSyncByteArrayInputStream(byte[]) - Constructor for class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
NonSyncByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
NonSyncByteArrayOutputStream - Class in org.apache.hadoop.hive.common.io
A thread-not-safe version of ByteArrayOutputStream, which removes all synchronized modifiers.
NonSyncByteArrayOutputStream(int) - Constructor for class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
NonSyncByteArrayOutputStream() - Constructor for class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
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
 
nonVectorizableChildOfGroupBy(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer
 
nonVerboseLayout - Static variable in class org.apache.hive.service.cli.CLIServiceUtils
 
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
 
NoopCommand - Class in org.apache.hive.hcatalog.api.repl.commands
This class is there to help testing, and to help initial development and will be the default Command for NoopReplicationTask This is not intended to be a permanent class, and will likely move to the test package after initial implementation.
NoopCommand() - Constructor for class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
Trivial ctor to support Writable reflections instantiation do not expect to use this object as-is, unless you call readFields after using this ctor
NoopCommand(long) - Constructor for class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
NoopReplicationTask - Class in org.apache.hive.hcatalog.api.repl
Noop replication task - a replication task that is actionable, does not need any further info, and returns NoopCommands.
NoopReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.NoopReplicationTask
 
NoopStreaming - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopStreaming.NoopStreamingResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopStreaming.NoopStreamingResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.NoopStreaming.NoopStreamingResolver
 
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
 
NoopWithMapStreaming - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopWithMapStreaming.NoopWithMapStreamingResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopWithMapStreaming.NoopWithMapStreamingResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMapStreaming.NoopWithMapStreamingResolver
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
normalizedColumnNames - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
normalizeIdentifier(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
normalizeSecondsAndNanos() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
Ensures that the seconds and nanoseconds fields have consistent sign
noscan - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
NoSuchCompareOpException - Exception in org.apache.hadoop.hive.accumulo.predicate
 
NoSuchCompareOpException() - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchCompareOpException
 
NoSuchCompareOpException(String) - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchCompareOpException
 
NoSuchCompareOpException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchCompareOpException
 
NoSuchLockException - Exception in org.apache.hadoop.hive.metastore.api
 
NoSuchLockException() - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
NoSuchLockException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
NoSuchLockException(NoSuchLockException) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
Performs a deep copy on other.
NoSuchLockException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
NoSuchObjectException - Exception in org.apache.hadoop.hive.metastore.api
 
NoSuchObjectException() - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
NoSuchObjectException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
NoSuchObjectException(NoSuchObjectException) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Performs a deep copy on other.
NoSuchObjectException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
NoSuchPrimitiveComparisonException - Exception in org.apache.hadoop.hive.accumulo.predicate
Used when a PrimitiveComparison was specified but one with that name cannot be found
NoSuchPrimitiveComparisonException() - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchPrimitiveComparisonException
 
NoSuchPrimitiveComparisonException(String) - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchPrimitiveComparisonException
 
NoSuchPrimitiveComparisonException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.predicate.NoSuchPrimitiveComparisonException
 
NoSuchTxnException - Exception in org.apache.hadoop.hive.metastore.api
 
NoSuchTxnException() - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
NoSuchTxnException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
NoSuchTxnException(NoSuchTxnException) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
Performs a deep copy on other.
NoSuchTxnException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
not() - Method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
 
NotAuthorizedException - Exception in org.apache.hive.hcatalog.templeton
Simple "user not found" type exception.
NotAuthorizedException(String) - Constructor for exception org.apache.hive.hcatalog.templeton.NotAuthorizedException
 
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
 
NotEqual - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps call to isEqual over PrimitiveComparison instance and returns the negation.
NotEqual() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.NotEqual
 
NotEqual(PrimitiveComparison) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.NotEqual
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
NotFoundException - Exception in org.apache.hive.hcatalog.templeton.tool
Simple not found exception.
NotFoundException(String) - Constructor for exception org.apache.hive.hcatalog.templeton.tool.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception org.apache.hive.hcatalog.templeton.tool.NotFoundException
 
NotificationEvent - Class in org.apache.hadoop.hive.metastore.api
 
NotificationEvent() - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
NotificationEvent(long, int, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
NotificationEvent(NotificationEvent) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEvent
Performs a deep copy on other.
NotificationEvent._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
NotificationEventRequest - Class in org.apache.hadoop.hive.metastore.api
 
NotificationEventRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
NotificationEventRequest(long) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
NotificationEventRequest(NotificationEventRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
Performs a deep copy on other.
NotificationEventRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
NotificationEventResponse - Class in org.apache.hadoop.hive.metastore.api
 
NotificationEventResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
NotificationEventResponse(List<NotificationEvent>) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
NotificationEventResponse(NotificationEventResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
Performs a deep copy on other.
NotificationEventResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
NotificationListener - Class in org.apache.hive.hcatalog.listener
Implementation of MetaStoreEventListener It sends message on two type of topics.
NotificationListener(Configuration) - Constructor for class org.apache.hive.hcatalog.listener.NotificationListener
Create message bus connection and session in constructor.
notifyBadConnectionUrl(String) - Method in class org.apache.hadoop.hive.contrib.metastore.hooks.SampleURLHook
 
notifyBadConnectionUrl(String) - Method in interface org.apache.hadoop.hive.metastore.hooks.JDOConnectionURLHook
Alerts this that the connection URL was bad.
NOTSKIPBIGTABLE - Static variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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 - Static variable in class org.apache.hive.hcatalog.data.DataType
 
NULL_HASHCODE - Static variable in class org.apache.hive.common.util.Murmur3
 
NULL_RESULT - Static variable in interface org.apache.hadoop.hive.ql.udf.generic.ISupportStreamingModeForWindowing
 
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
 
nullByte - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
nullBytes - Static variable in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
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
 
nullCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
nullCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
nullDefinedAs(char) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
nullDefinedAs(char) - Method in class org.apache.hive.hcatalog.api.HCatTable
See row_format element of CREATE_TABLE DDL for Hive.
nullPlusNonNullIsNull() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
NullRecordReader - Class in org.apache.hive.hcatalog.templeton.tool
An empty record reader.
NullRecordReader() - Constructor for class org.apache.hive.hcatalog.templeton.tool.NullRecordReader
 
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.
nullsafes - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
nullsAreSortedAtEnd() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedAtStart() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedHigh() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedLow() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
NullScanOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
This optimizer attempts following two optimizations: 1.
NullScanOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.NullScanOptimizer
 
NullScanTaskDispatcher - Class in org.apache.hadoop.hive.ql.optimizer.physical
Iterate over all tasks one by one and removes all input paths from task if conditions as defined in rules match.
NullScanTaskDispatcher(PhysicalContext, Map<Rule, NodeProcessor>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.NullScanTaskDispatcher
 
nullSequence - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
NullSplit - Class in org.apache.hive.hcatalog.templeton.tool
An empty splitter.
NullSplit() - Constructor for class org.apache.hive.hcatalog.templeton.tool.NullSplit
 
nullString - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The string representing nulls in the serialized data.
nullStringOutput - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
nullStringStorage - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
NullStructSerDe - Class in org.apache.hadoop.hive.serde2
Placeholder SerDe for cases where neither serialization nor deserialization is needed
NullStructSerDe() - Constructor for class org.apache.hadoop.hive.serde2.NullStructSerDe
 
NullStructSerDe.NullStructSerDeObjectInspector - Class in org.apache.hadoop.hive.serde2
A object inspector for null struct serde.
NullStructSerDe.NullStructSerDeObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.NullStructSerDe.NullStructSerDeObjectInspector
 
nullText - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The nullString in UTF-8 bytes.
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
 
NUM_FILES - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
The name of the statistic Num Files to be published or gathered.
NUM_PARTITIONS - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
The name of the statistic Num Partitions to be published or gathered.
NUM_RETRIES - Static variable in class org.apache.hive.hcatalog.listener.NotificationListener
 
numAliases - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
numberOfBuckets - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
NUMBEROFROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
NUMBEROFROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
NUMBEROFVALUES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
numBits - Variable in class org.apache.hive.common.util.BloomFilter
 
numBitVectors - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
numBitVectorsField - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
numBitVectorsFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
numBuckets(int) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for number of buckets.
numCols - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
numCols - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
numColumns() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
numColumns() - Method in class org.apache.hive.service.cli.RowBasedSet
 
numColumns() - Method in interface org.apache.hive.service.cli.RowSet
 
numDistinctExprs - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
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
 
numDistributionKeys - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
numDynParts - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
numDynParts - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.TableSpec
 
numEntriesHashTable - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
Current number of entries in the hash table.
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.
numFollowing - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator
 
numHashFunctions - Variable in class org.apache.hive.common.util.BloomFilter
 
NUMHASHFUNCTIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
numPreceding - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator
 
numPrimitiveTypes() - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
 
numRows - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
numRows - Variable in class org.apache.hadoop.hive.ql.exec.MapOperator
 
numRows - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
numRows() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
numRows() - Method in class org.apache.hive.service.cli.RowBasedSet
 
numRows() - Method in interface org.apache.hive.service.cli.RowSet
 
numSplits() - Method in interface org.apache.hive.hcatalog.data.transfer.ReaderContext
Determine the number of splits available in this ReaderContext.
numVectorsOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 

O

o - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
object - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow.Extractor
 
object() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
object - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
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.
objectClass - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
ObjectContainer<ROW> - Class in org.apache.hadoop.hive.ql.exec.persistence
An eager object container that puts every row directly to output stream.
ObjectContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
ObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspector helps us to look into the internal structure of a complex object.
ObjectInspector.Category - Enum in org.apache.hadoop.hive.serde2.objectinspector
Category.
ObjectInspectorConverters - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorConverters.
ObjectInspectorConverters.Converter - Interface in org.apache.hadoop.hive.serde2.objectinspector
A converter which will convert objects with one ObjectInspector to another.
ObjectInspectorConverters.IdentityConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
IdentityConverter.
ObjectInspectorConverters.IdentityConverter() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.IdentityConverter
 
ObjectInspectorConverters.ListConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for List.
ObjectInspectorConverters.ListConverter(ObjectInspector, SettableListObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.ListConverter
 
ObjectInspectorConverters.MapConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for Map.
ObjectInspectorConverters.MapConverter(ObjectInspector, SettableMapObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.MapConverter
 
ObjectInspectorConverters.StructConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for Struct.
ObjectInspectorConverters.StructConverter(ObjectInspector, SettableStructObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.StructConverter
 
ObjectInspectorConverters.UnionConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for Union.
ObjectInspectorConverters.UnionConverter(ObjectInspector, SettableUnionObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.UnionConverter
 
ObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
ObjectInspectorFactory.ObjectInspectorOptions - Enum in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorOptions describes what ObjectInspector to use.
ObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
ObjectInspectorUtils.ObjectInspectorCopyOption - Enum in org.apache.hadoop.hive.serde2.objectinspector
This enum controls how we copy primitive objects.
ObjectNotFoundException - Exception in org.apache.hive.hcatalog.api
This exception is thrown when a Database, Table or Partition specified in an HCatalog query is not found.
ObjectNotFoundException(String, Throwable) - Constructor for exception org.apache.hive.hcatalog.api.ObjectNotFoundException
 
ObjectPair<F,S> - Class in org.apache.hadoop.hive.common
 
ObjectPair() - Constructor for class org.apache.hadoop.hive.common.ObjectPair
 
ObjectPair(F, S) - Constructor for class org.apache.hadoop.hive.common.ObjectPair
 
ObjectStore - Class in org.apache.hadoop.hive.metastore
This class is the interface between the application logic and the database store that contains the objects.
ObjectStore() - Constructor for class org.apache.hadoop.hive.metastore.ObjectStore
 
ObjectStore.UpdateMDatabaseURIRetVal - Class in org.apache.hadoop.hive.metastore
 
ObjectStore.UpdateMStorageDescriptorTblURIRetVal - Class in org.apache.hadoop.hive.metastore
 
ObjectStore.UpdatePropURIRetVal - Class in org.apache.hadoop.hive.metastore
 
ObjectStore.UpdateSerdeURIRetVal - Class in org.apache.hadoop.hive.metastore
 
objectType - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
objsize - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
obtainDateConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
obtainDoubleConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
obtainIntConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
obtainLongConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
obtainStringConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
obtainTimestampConverter(ObjectInspector[], int, PrimitiveObjectInspector.PrimitiveCategory[], ObjectInspectorConverters.Converter[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
oc - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
offline - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
offset - Variable in class org.apache.hadoop.hive.common.DiskRange
The first address.
OFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
offsets - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
oi - Static variable in class org.apache.hadoop.hive.ql.io.RecordIdentifier.StructInfo
 
OI - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
oi - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
oi - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
onAddIndex(AddIndexEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onAddPartition(AddPartitionEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onAddPartition(AddPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onAddPartition(AddPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
onAlterIndex(AlterIndexEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onAlterPartition(AlterPartitionEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onAlterPartition(AlterPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onAlterPartition(AlterPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
onAlterTable(AlterTableEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onAlterTable(AlterTableEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onAlterTable(AlterTableEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Send altered table notifications.
onApplicationEnd(SparkListenerApplicationEnd) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onApplicationStart(SparkListenerApplicationStart) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onBlockManagerAdded(SparkListenerBlockManagerAdded) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onBlockManagerRemoved(SparkListenerBlockManagerRemoved) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onConfigChange(ConfigChangeEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onConfigChange(ConfigChangeEvent) - Method in class org.apache.hadoop.hive.metastore.SessionPropertiesListener
 
onConfigChange(ConfigChangeEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onCreateDatabase(CreateDatabaseEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onCreateDatabase(CreateDatabaseEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onCreateDatabase(CreateDatabaseEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
onCreateTable(CreateTableEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onCreateTable(CreateTableEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onCreateTable(CreateTableEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
onDropDatabase(DropDatabaseEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onDropDatabase(DropDatabaseEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onDropDatabase(DropDatabaseEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
onDropIndex(DropIndexEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onDropPartition(DropPartitionEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onDropPartition(DropPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onDropPartition(DropPartitionEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Send dropped partition notifications.
onDropTable(DropTableEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onDropTable(DropTableEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onDropTable(DropTableEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Send dropped table notifications.
ONE - Static variable in class org.apache.hadoop.hive.common.type.Decimal128
 
ONE - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
onEndFunction(String, MetaStoreEndFunctionContext) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionListener
 
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
 
onEnvironmentUpdate(SparkListenerEnvironmentUpdate) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onEvent(PreEventContext) - Method in class org.apache.hadoop.hive.metastore.MetaStorePreEventListener
 
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
 
onExecutorAdded(SparkListenerExecutorAdded) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onExecutorRemoved(SparkListenerExecutorRemoved) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onInit(MetaStoreInitContext) - Method in class org.apache.hadoop.hive.metastore.MetaStoreInitListener
 
onInsert(InsertEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
This will be called when an insert is executed that does not cause a partition to be added.
onInsert(InsertEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onJobCancelled(JobHandle<T>) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
 
onJobEnd(SparkListenerJobEnd) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onJobFailed(JobHandle<T>, Throwable) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
 
onJobQueued(JobHandle<T>) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
 
onJobStart(SparkListenerJobStart) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onJobStarted(JobHandle<T>) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
 
onJobSucceeded(JobHandle<T>, T) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
 
onLoadPartitionDone(LoadPartitionDoneEvent) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
onLoadPartitionDone(LoadPartitionDoneEvent) - Method in class org.apache.hive.hcatalog.listener.DbNotificationListener
 
onLoadPartitionDone(LoadPartitionDoneEvent) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
ONLY_FOR_TESTING - Static variable in enum org.apache.hadoop.hive.ql.processors.HiveCommand
 
onlyContainsPartnCols(Table, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Find out whether the condition only contains partitioned columns.
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveExpandDistinctAggregatesRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinMergeRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule.HiveFilterJoinTransposeRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinAddNotNullRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinCommuteRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinPushTransitivePredicatesRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinToMultiJoinRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePartitionPruneRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePreFilteringRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveWindowingFixRule
 
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
 
onSparkJobStarted(JobHandle<T>, int) - Method in interface org.apache.hive.spark.client.JobHandle.Listener
Called when a monitored Spark job is started on the remote context.
onStageCompleted(SparkListenerStageCompleted) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onStageSubmitted(SparkListenerStageSubmitted) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onTaskEnd(SparkListenerTaskEnd) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onTaskGettingResult(SparkListenerTaskGettingResult) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onTaskStart(SparkListenerTaskStart) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
onUnpersistRDD(SparkListenerUnpersistRDD) - Method in class org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener
 
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
 
onVertexStateUpdated(VertexStateUpdate) - Method in class org.apache.hadoop.hive.ql.exec.tez.HiveSplitGenerator
 
Op - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
Op(String, String, String, List<Op>, List<Attr>, JSONObject, Vertex) - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.Op
 
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
 
opDisplayName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseBinary
 
opDisplayName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
opDisplayName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
open(Path, int) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
open() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Opens scope, and makes note of the time started, increments run counter
open(HiveConf) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
Initializes a Spark session for DAG execution.
open(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
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.
open() - Method in class org.apache.hadoop.hive.thrift.client.TUGIAssumingTransport
 
open() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
open(String, Configuration) - Method in class org.apache.hive.hcatalog.templeton.SecureProxySupport
Create the delegation token.
open() - Method in class org.apache.hive.service.auth.TSubjectAssumingTransport
 
open(Map<String, String>) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
open(Map<String, String>) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
open_txns(OpenTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.open_txns_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
open_txns(OpenTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.open_txns_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
open_txns(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
open_txns(OpenTxnRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
open_txns(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
OpenCSVSerde - Class in org.apache.hadoop.hive.serde2
OpenCSVSerde use opencsv to deserialize CSV format.
OpenCSVSerde() - Constructor for class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
openFile(FileSystem, Path, int, long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Override this method to specialize the type of FSDataInputStream returned.
openNodeScope(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
openSession(TProtocolVersion, String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.CLIService
openSession(TProtocolVersion, String, String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.CLIService
 
openSession(String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.CLIService
 
openSession(String, String) - Method in class org.apache.hive.service.cli.CLIServiceClient
 
openSession(String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
openSession(String, String, Map<String, String>) - Method in interface org.apache.hive.service.cli.ICLIService
 
openSession(TProtocolVersion, String, String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.session.SessionManager
 
openSession(TProtocolVersion, String, String, String, Map<String, String>, boolean, String) - Method in class org.apache.hive.service.cli.session.SessionManager
Opens a new session and creates a session handle.
OpenSession(TOpenSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.OpenSession_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
OpenSession(TOpenSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.OpenSession_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
OpenSession(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
OpenSession(TOpenSessionReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
OpenSession(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
openSession(String, String, Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
openSessionWithImpersonation(TProtocolVersion, String, String, Map<String, String>, String) - Method in class org.apache.hive.service.cli.CLIService
openSessionWithImpersonation(TProtocolVersion, String, String, String, Map<String, String>, String) - Method in class org.apache.hive.service.cli.CLIService
 
openSessionWithImpersonation(String, String, Map<String, String>, String) - Method in class org.apache.hive.service.cli.CLIService
 
openSessionWithImpersonation(String, String, Map<String, String>, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
openSessionWithImpersonation(String, String, Map<String, String>, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
openSessionWithImpersonation(String, String, Map<String, String>, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
openStorage(Configuration) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
openStorage(Configuration) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
For storage methods that require a connection, this is a hint that it's time to open a connection.
openStorage(Configuration) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
openTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Opens a new one or the one already created Every call of this function must have corresponding commit or rollback function call
openTransaction() - Method in interface org.apache.hadoop.hive.metastore.RawStore
Opens a new one or the one already created Every call of this function must have corresponding commit or rollback function call
openTxn(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
openTxn(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Initiate a transaction.
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.
OpenTxnRequest - Class in org.apache.hadoop.hive.metastore.api
 
OpenTxnRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
OpenTxnRequest(int, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
OpenTxnRequest(OpenTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
Performs a deep copy on other.
OpenTxnRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
openTxns(String, int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
openTxns(String, int) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Initiate a batch of transactions.
openTxns(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
OpenTxnsResponse - Class in org.apache.hadoop.hive.metastore.api
 
OpenTxnsResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
OpenTxnsResponse(List<Long>) - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
OpenTxnsResponse(OpenTxnsResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
Performs a deep copy on other.
OpenTxnsResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
operation - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
Operation - Class in org.apache.hive.service.cli.operation
 
Operation(HiveSession, OperationType, boolean) - Constructor for class org.apache.hive.service.cli.operation.Operation
 
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
 
Operation2Privilege.IOType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
operationException - Variable in class org.apache.hive.service.cli.operation.Operation
 
OperationHandle - Class in org.apache.hive.service.cli
 
OperationHandle(OperationType, TProtocolVersion) - Constructor for class org.apache.hive.service.cli.OperationHandle
 
OperationHandle(TOperationHandle) - Constructor for class org.apache.hive.service.cli.OperationHandle
 
OperationHandle(TOperationHandle, TProtocolVersion) - Constructor for class org.apache.hive.service.cli.OperationHandle
 
OperationLog - Class in org.apache.hadoop.hive.ql.session
OperationLog wraps the actual operation log file, and provides interface for accessing, reading, writing, and removing the file.
OperationLog(String, File, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.session.OperationLog
 
operationLog - Variable in class org.apache.hive.service.cli.operation.Operation
 
OperationLog.LoggingLevel - Enum in org.apache.hadoop.hive.ql.session
 
OperationManager - Class in org.apache.hive.service.cli.operation
OperationManager.
OperationManager() - Constructor for class org.apache.hive.service.cli.operation.OperationManager
 
OperationState - Enum in org.apache.hive.service.cli
OperationState.
OperationStatus - Class in org.apache.hive.service.cli
OperationStatus
OperationStatus(OperationState, HiveSQLException) - Constructor for class org.apache.hive.service.cli.OperationStatus
 
OperationType - Enum in org.apache.hive.service.cli
OperationType.
operator - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
operator() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
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 - Class in org.apache.hadoop.hive.ql.plan.api
 
Operator() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
 
Operator(String, OperatorType, Map<String, String>, Map<String, Long>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
 
Operator(Operator) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
Performs a deep copy on other.
Operator._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
operatorExpression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
OperatorFactory - Class in org.apache.hadoop.hive.ql.exec
OperatorFactory.
operatorId - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
OperatorType - Enum in org.apache.hadoop.hive.ql.plan.api
 
OperatorUtils - Class in org.apache.hadoop.hive.ql.exec
 
OperatorUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
opMergeJoinWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
opName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseBinary
 
opName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
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
 
opParseCtx - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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.PTFPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.PTFPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.PTFPPD
 
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.ReduceSinkPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.ReduceSinkPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.ReduceSinkPPD
 
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
 
opProps - Variable in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
oprot_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
protocols are protected in case any of their properties need to be queried from another class in this package.
opStack - Variable in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
opStack - Variable in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
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.
optimizeOperatorPlan(ParseContext, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
 
optimizeOperatorPlan(ParseContext, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
optimizeOperatorPlan(ParseContext, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
Optimizer - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of the optimizer.
Optimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
OptimizeSparkProcContext - Class in org.apache.hadoop.hive.ql.parse.spark
OptimizeSparkProcContext.
OptimizeSparkProcContext(HiveConf, ParseContext, Set<ReadEntity>, Set<WriteEntity>, Deque<Operator<? extends OperatorDesc>>) - Constructor for class org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext
 
optimizeTaskPlan(List<Task<? extends Serializable>>, ParseContext, Context) - Method in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
optimizeTaskPlan(List<Task<? extends Serializable>>, ParseContext, Context) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
 
optimizeTaskPlan(List<Task<? extends Serializable>>, ParseContext, Context) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
optimizeTaskPlan(List<Task<? extends Serializable>>, ParseContext, Context) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
OptimizeTezProcContext - Class in org.apache.hadoop.hive.ql.parse
OptimizeTezProcContext.
OptimizeTezProcContext(HiveConf, ParseContext, Set<ReadEntity>, Set<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
OPTIONS - Variable in class org.apache.hadoop.hive.common.cli.CommonCliOptions
Options for parsing the command line.
OptionsProcessor - Class in org.apache.hadoop.hive.cli
OptionsProcessor.
OptionsProcessor() - Constructor for class org.apache.hadoop.hive.cli.OptionsProcessor
 
opTraits - Variable in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
OpTraits - Class in org.apache.hadoop.hive.ql.plan
 
OpTraits(List<List<String>>, int, List<List<String>>) - 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
 
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 - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
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 - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
OrcFile - Class in org.apache.hadoop.hive.ql.io.orc
Contains factory methods to read or write ORC files.
OrcFile.CompressionStrategy - Enum in org.apache.hadoop.hive.ql.io.orc
 
OrcFile.EncodingStrategy - Enum in org.apache.hadoop.hive.ql.io.orc
 
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.ReaderOptions(Configuration) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcFile.ReaderOptions
 
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.
OrcFile.WriterVersion - Enum in org.apache.hadoop.hive.ql.io.orc
Records the version of the writer in terms of which bugs have been fixed.
OrcFileKeyWrapper - Class in org.apache.hadoop.hive.ql.io.orc
Key for OrcFileMergeMapper task.
OrcFileKeyWrapper() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
OrcFileMergeDesc - Class in org.apache.hadoop.hive.ql.plan
ORC fast file merge operator descriptor.
OrcFileMergeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.OrcFileMergeDesc
 
OrcFileMergeDesc(DynamicPartitionCtx, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.OrcFileMergeDesc
 
OrcFileMergeOperator - Class in org.apache.hadoop.hive.ql.exec
Fast file merge operator for ORC files.
OrcFileMergeOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.OrcFileMergeOperator
 
ORCFileStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
ORCFileStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.ORCFileStorageFormatDescriptor
 
OrcFileStripeMergeInputFormat - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcFileStripeMergeInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeInputFormat
 
OrcFileStripeMergeRecordReader - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcFileStripeMergeRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
OrcFileValueWrapper - Class in org.apache.hadoop.hive.ql.io.orc
Value for OrcFileMergeMapper.
OrcFileValueWrapper() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
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
 
OrcInputFormat.NullKeyRecordReader - Class in org.apache.hadoop.hive.ql.io.orc
Return a RecordReader that is compatible with the Hive 0.12 reader with NullWritable for the key instead of RecordIdentifier.
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() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
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
 
OrcProto - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.BinaryStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BinaryStatistics
OrcProto.BinaryStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BinaryStatistics
OrcProto.BinaryStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.BloomFilter - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BloomFilter
OrcProto.BloomFilter.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BloomFilter
OrcProto.BloomFilterIndex - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BloomFilterIndex
OrcProto.BloomFilterIndex.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BloomFilterIndex
OrcProto.BloomFilterIndexOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.BloomFilterOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.BucketStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BucketStatistics
OrcProto.BucketStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.BucketStatistics
OrcProto.BucketStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.ColumnEncoding - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.ColumnEncoding
OrcProto.ColumnEncoding.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.ColumnEncoding
OrcProto.ColumnEncoding.Kind - Enum in org.apache.hadoop.hive.ql.io.orc
Protobuf enum orc.proto.ColumnEncoding.Kind
OrcProto.ColumnEncodingOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.ColumnStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.ColumnStatistics
OrcProto.ColumnStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.ColumnStatistics
OrcProto.ColumnStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.CompressionKind - Enum in org.apache.hadoop.hive.ql.io.orc
Protobuf enum orc.proto.CompressionKind
OrcProto.DateStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DateStatistics
OrcProto.DateStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DateStatistics
OrcProto.DateStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.DecimalStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DecimalStatistics
OrcProto.DecimalStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DecimalStatistics
OrcProto.DecimalStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.DoubleStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DoubleStatistics
OrcProto.DoubleStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.DoubleStatistics
OrcProto.DoubleStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.Footer - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Footer
OrcProto.Footer.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Footer
OrcProto.FooterOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.IntegerStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.IntegerStatistics
OrcProto.IntegerStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.IntegerStatistics
OrcProto.IntegerStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.Metadata - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Metadata
OrcProto.Metadata.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Metadata
OrcProto.MetadataOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.PostScript - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.PostScript
OrcProto.PostScript.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.PostScript
OrcProto.PostScriptOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.RowIndex - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.RowIndex
OrcProto.RowIndex.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.RowIndex
OrcProto.RowIndexEntry - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.RowIndexEntry
OrcProto.RowIndexEntry.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.RowIndexEntry
OrcProto.RowIndexEntryOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.RowIndexOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.Stream - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Stream
OrcProto.Stream.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Stream
OrcProto.Stream.Kind - Enum in org.apache.hadoop.hive.ql.io.orc
Protobuf enum orc.proto.Stream.Kind
OrcProto.StreamOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.StringStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StringStatistics
OrcProto.StringStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StringStatistics
OrcProto.StringStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.StripeFooter - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeFooter
OrcProto.StripeFooter.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeFooter
OrcProto.StripeFooterOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.StripeInformation - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeInformation
OrcProto.StripeInformation.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeInformation
OrcProto.StripeInformationOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.StripeStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeStatistics
OrcProto.StripeStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.StripeStatistics
OrcProto.StripeStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.TimestampStatistics - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.TimestampStatistics
OrcProto.TimestampStatistics.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.TimestampStatistics
OrcProto.TimestampStatisticsOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.Type - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Type
OrcProto.Type.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.Type
OrcProto.Type.Kind - Enum in org.apache.hadoop.hive.ql.io.orc
Protobuf enum orc.proto.Type.Kind
OrcProto.TypeOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcProto.UserMetadataItem - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.UserMetadataItem
OrcProto.UserMetadataItem.Builder - Class in org.apache.hadoop.hive.ql.io.orc
Protobuf type orc.proto.UserMetadataItem
OrcProto.UserMetadataItemOrBuilder - Interface in org.apache.hadoop.hive.ql.io.orc
 
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() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
OrcSplit(Path, long, long, String[], ReaderImpl.FileMetaInfo, boolean, boolean, List<Long>, long) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
OrcStruct - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcUtils - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcUtils() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcUtils
 
Order - Class in org.apache.hadoop.hive.metastore.api
 
Order() - Constructor for class org.apache.hadoop.hive.metastore.api.Order
 
Order(String, int) - Constructor for class org.apache.hadoop.hive.metastore.api.Order
 
Order(Order) - Constructor for class org.apache.hadoop.hive.metastore.api.Order
Performs a deep copy on other.
order - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
order - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
Order._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
orderByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
orderByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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
 
orderedColumnsContain(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
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
 
orderRelNode(RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
orExpression() - Method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
org.apache.hadoop.fs - package org.apache.hadoop.fs
 
org.apache.hadoop.hive.accumulo - package org.apache.hadoop.hive.accumulo
Serde and InputFormat support for connecting Hive to Accumulo tables.
org.apache.hadoop.hive.accumulo.columns - package org.apache.hadoop.hive.accumulo.columns
 
org.apache.hadoop.hive.accumulo.mr - package org.apache.hadoop.hive.accumulo.mr
 
org.apache.hadoop.hive.accumulo.predicate - package org.apache.hadoop.hive.accumulo.predicate
Predicate pushdown to Accumulo filter iterators.
org.apache.hadoop.hive.accumulo.predicate.compare - package org.apache.hadoop.hive.accumulo.predicate.compare
PrimitiveCompare and CompareOpt implementations for use in PrimitiveComparisonFilter iterator
org.apache.hadoop.hive.accumulo.serde - package org.apache.hadoop.hive.accumulo.serde
 
org.apache.hadoop.hive.ant - package org.apache.hadoop.hive.ant
 
org.apache.hadoop.hive.cli - package org.apache.hadoop.hive.cli
 
org.apache.hadoop.hive.common - package org.apache.hadoop.hive.common
 
org.apache.hadoop.hive.common.classification - package org.apache.hadoop.hive.common.classification
 
org.apache.hadoop.hive.common.cli - package org.apache.hadoop.hive.common.cli
 
org.apache.hadoop.hive.common.io - package org.apache.hadoop.hive.common.io
 
org.apache.hadoop.hive.common.jsonexplain - package org.apache.hadoop.hive.common.jsonexplain
 
org.apache.hadoop.hive.common.jsonexplain.tez - package org.apache.hadoop.hive.common.jsonexplain.tez
 
org.apache.hadoop.hive.common.metrics - package org.apache.hadoop.hive.common.metrics
 
org.apache.hadoop.hive.common.type - package org.apache.hadoop.hive.common.type
 
org.apache.hadoop.hive.conf - package org.apache.hadoop.hive.conf
 
org.apache.hadoop.hive.contrib.fileformat.base64 - package org.apache.hadoop.hive.contrib.fileformat.base64
 
org.apache.hadoop.hive.contrib.genericudf.example - package org.apache.hadoop.hive.contrib.genericudf.example
 
org.apache.hadoop.hive.contrib.metastore.hooks - package org.apache.hadoop.hive.contrib.metastore.hooks
 
org.apache.hadoop.hive.contrib.mr - package org.apache.hadoop.hive.contrib.mr
 
org.apache.hadoop.hive.contrib.mr.example - package org.apache.hadoop.hive.contrib.mr.example
 
org.apache.hadoop.hive.contrib.serde2 - package org.apache.hadoop.hive.contrib.serde2
 
org.apache.hadoop.hive.contrib.serde2.s3 - package org.apache.hadoop.hive.contrib.serde2.s3
 
org.apache.hadoop.hive.contrib.udaf.example - package org.apache.hadoop.hive.contrib.udaf.example
 
org.apache.hadoop.hive.contrib.udf - package org.apache.hadoop.hive.contrib.udf
 
org.apache.hadoop.hive.contrib.udf.example - package org.apache.hadoop.hive.contrib.udf.example
 
org.apache.hadoop.hive.contrib.udtf.example - package org.apache.hadoop.hive.contrib.udtf.example
 
org.apache.hadoop.hive.contrib.util.typedbytes - package org.apache.hadoop.hive.contrib.util.typedbytes
 
org.apache.hadoop.hive.hbase - package org.apache.hadoop.hive.hbase
Implements an HBase storage handler for Hive.
org.apache.hadoop.hive.hbase.struct - package org.apache.hadoop.hive.hbase.struct
 
org.apache.hadoop.hive.hwi - package org.apache.hadoop.hive.hwi
 
org.apache.hadoop.hive.io - package org.apache.hadoop.hive.io
 
org.apache.hadoop.hive.metastore - package org.apache.hadoop.hive.metastore
 
org.apache.hadoop.hive.metastore.api - package org.apache.hadoop.hive.metastore.api
 
org.apache.hadoop.hive.metastore.events - package org.apache.hadoop.hive.metastore.events
 
org.apache.hadoop.hive.metastore.hooks - package org.apache.hadoop.hive.metastore.hooks
 
org.apache.hadoop.hive.metastore.model - package org.apache.hadoop.hive.metastore.model
 
org.apache.hadoop.hive.metastore.parser - package org.apache.hadoop.hive.metastore.parser
This package implements the parser for parsing the string filter for the listPartitionsByFilter API.
org.apache.hadoop.hive.metastore.partition.spec - package org.apache.hadoop.hive.metastore.partition.spec
 
org.apache.hadoop.hive.metastore.tools - package org.apache.hadoop.hive.metastore.tools
 
org.apache.hadoop.hive.metastore.txn - package org.apache.hadoop.hive.metastore.txn
 
org.apache.hadoop.hive.ql - package org.apache.hadoop.hive.ql
 
org.apache.hadoop.hive.ql.debug - package org.apache.hadoop.hive.ql.debug
 
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.spark - package org.apache.hadoop.hive.ql.exec.spark
 
org.apache.hadoop.hive.ql.exec.spark.session - package org.apache.hadoop.hive.ql.exec.spark.session
 
org.apache.hadoop.hive.ql.exec.spark.Statistic - package org.apache.hadoop.hive.ql.exec.spark.Statistic
 
org.apache.hadoop.hive.ql.exec.spark.status - package org.apache.hadoop.hive.ql.exec.spark.status
 
org.apache.hadoop.hive.ql.exec.spark.status.impl - package org.apache.hadoop.hive.ql.exec.spark.status.impl
 
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.expressions.aggregates.gen - package org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
 
org.apache.hadoop.hive.ql.exec.vector.expressions.gen - package org.apache.hadoop.hive.ql.exec.vector.expressions.gen
 
org.apache.hadoop.hive.ql.exec.vector.mapjoin - package org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast - package org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable - package org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized - package org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
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.filters - package org.apache.hadoop.hive.ql.io.filters
 
org.apache.hadoop.hive.ql.io.merge - package org.apache.hadoop.hive.ql.io.merge
 
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.timestamp - package org.apache.hadoop.hive.ql.io.parquet.timestamp
 
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.calcite - package org.apache.hadoop.hive.ql.optimizer.calcite
 
org.apache.hadoop.hive.ql.optimizer.calcite.cost - package org.apache.hadoop.hive.ql.optimizer.calcite.cost
 
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators - package org.apache.hadoop.hive.ql.optimizer.calcite.reloperators
 
org.apache.hadoop.hive.ql.optimizer.calcite.rules - package org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
org.apache.hadoop.hive.ql.optimizer.calcite.stats - package org.apache.hadoop.hive.ql.optimizer.calcite.stats
 
org.apache.hadoop.hive.ql.optimizer.calcite.translator - package org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
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.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.spark - package org.apache.hadoop.hive.ql.optimizer.spark
 
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.parse.spark - package org.apache.hadoop.hive.ql.parse.spark
 
org.apache.hadoop.hive.ql.plan - package org.apache.hadoop.hive.ql.plan
 
org.apache.hadoop.hive.ql.plan.api - package org.apache.hadoop.hive.ql.plan.api
 
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
 
org.apache.hadoop.hive.schshim - package org.apache.hadoop.hive.schshim
 
org.apache.hadoop.hive.serde - package org.apache.hadoop.hive.serde
 
org.apache.hadoop.hive.serde.test - package org.apache.hadoop.hive.serde.test
 
org.apache.hadoop.hive.serde2 - package org.apache.hadoop.hive.serde2
 
org.apache.hadoop.hive.serde2.avro - package org.apache.hadoop.hive.serde2.avro
 
org.apache.hadoop.hive.serde2.binarysortable - package org.apache.hadoop.hive.serde2.binarysortable
 
org.apache.hadoop.hive.serde2.binarysortable.fast - package org.apache.hadoop.hive.serde2.binarysortable.fast
 
org.apache.hadoop.hive.serde2.columnar - package org.apache.hadoop.hive.serde2.columnar
 
org.apache.hadoop.hive.serde2.dynamic_type - package org.apache.hadoop.hive.serde2.dynamic_type
 
org.apache.hadoop.hive.serde2.fast - package org.apache.hadoop.hive.serde2.fast
 
org.apache.hadoop.hive.serde2.io - package org.apache.hadoop.hive.serde2.io
 
org.apache.hadoop.hive.serde2.lazy - package org.apache.hadoop.hive.serde2.lazy
 
org.apache.hadoop.hive.serde2.lazy.fast - package org.apache.hadoop.hive.serde2.lazy.fast
 
org.apache.hadoop.hive.serde2.lazy.objectinspector - package org.apache.hadoop.hive.serde2.lazy.objectinspector
 
org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive - package org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 
org.apache.hadoop.hive.serde2.lazybinary - package org.apache.hadoop.hive.serde2.lazybinary
 
org.apache.hadoop.hive.serde2.lazybinary.fast - package org.apache.hadoop.hive.serde2.lazybinary.fast
 
org.apache.hadoop.hive.serde2.lazybinary.objectinspector - package org.apache.hadoop.hive.serde2.lazybinary.objectinspector
 
org.apache.hadoop.hive.serde2.lazydio - package org.apache.hadoop.hive.serde2.lazydio
 
org.apache.hadoop.hive.serde2.objectinspector - package org.apache.hadoop.hive.serde2.objectinspector
 
org.apache.hadoop.hive.serde2.objectinspector.primitive - package org.apache.hadoop.hive.serde2.objectinspector.primitive
 
org.apache.hadoop.hive.serde2.proto.test - package org.apache.hadoop.hive.serde2.proto.test
 
org.apache.hadoop.hive.serde2.thrift - package org.apache.hadoop.hive.serde2.thrift
 
org.apache.hadoop.hive.serde2.thrift.test - package org.apache.hadoop.hive.serde2.thrift.test
 
org.apache.hadoop.hive.serde2.typeinfo - package org.apache.hadoop.hive.serde2.typeinfo
This package provides the implementation of the SerDe type system.
org.apache.hadoop.hive.service - package org.apache.hadoop.hive.service
 
org.apache.hadoop.hive.shims - package org.apache.hadoop.hive.shims
 
org.apache.hadoop.hive.thrift - package org.apache.hadoop.hive.thrift
 
org.apache.hadoop.hive.thrift.client - package org.apache.hadoop.hive.thrift.client
 
org.apache.hadoop.mapred - package org.apache.hadoop.mapred
 
org.apache.hadoop.security.token.delegation - package org.apache.hadoop.security.token.delegation
 
org.apache.hive.beeline - package org.apache.hive.beeline
 
org.apache.hive.beeline.util - package org.apache.hive.beeline.util
 
org.apache.hive.common - package org.apache.hive.common
 
org.apache.hive.common.util - package org.apache.hive.common.util
 
org.apache.hive.hcatalog.api - package org.apache.hive.hcatalog.api
 
org.apache.hive.hcatalog.api.repl - package org.apache.hive.hcatalog.api.repl
 
org.apache.hive.hcatalog.api.repl.commands - package org.apache.hive.hcatalog.api.repl.commands
 
org.apache.hive.hcatalog.api.repl.exim - package org.apache.hive.hcatalog.api.repl.exim
 
org.apache.hive.hcatalog.cli - package org.apache.hive.hcatalog.cli
 
org.apache.hive.hcatalog.cli.SemanticAnalysis - package org.apache.hive.hcatalog.cli.SemanticAnalysis
 
org.apache.hive.hcatalog.common - package org.apache.hive.hcatalog.common
 
org.apache.hive.hcatalog.data - package org.apache.hive.hcatalog.data
 
org.apache.hive.hcatalog.data.schema - package org.apache.hive.hcatalog.data.schema
 
org.apache.hive.hcatalog.data.transfer - package org.apache.hive.hcatalog.data.transfer
 
org.apache.hive.hcatalog.data.transfer.impl - package org.apache.hive.hcatalog.data.transfer.impl
 
org.apache.hive.hcatalog.data.transfer.state - package org.apache.hive.hcatalog.data.transfer.state
 
org.apache.hive.hcatalog.har - package org.apache.hive.hcatalog.har
 
org.apache.hive.hcatalog.listener - package org.apache.hive.hcatalog.listener
 
org.apache.hive.hcatalog.mapreduce - package org.apache.hive.hcatalog.mapreduce
 
org.apache.hive.hcatalog.messaging - package org.apache.hive.hcatalog.messaging
 
org.apache.hive.hcatalog.messaging.jms - package org.apache.hive.hcatalog.messaging.jms
 
org.apache.hive.hcatalog.messaging.json - package org.apache.hive.hcatalog.messaging.json
 
org.apache.hive.hcatalog.oozie - package org.apache.hive.hcatalog.oozie
 
org.apache.hive.hcatalog.pig - package org.apache.hive.hcatalog.pig
 
org.apache.hive.hcatalog.rcfile - package org.apache.hive.hcatalog.rcfile
 
org.apache.hive.hcatalog.storagehandler - package org.apache.hive.hcatalog.storagehandler
 
org.apache.hive.hcatalog.streaming - package org.apache.hive.hcatalog.streaming
HCatalog Streaming API -- high level description
org.apache.hive.hcatalog.templeton - package org.apache.hive.hcatalog.templeton
 
org.apache.hive.hcatalog.templeton.tool - package org.apache.hive.hcatalog.templeton.tool
 
org.apache.hive.jdbc - package org.apache.hive.jdbc
 
org.apache.hive.service - package org.apache.hive.service
 
org.apache.hive.service.auth - package org.apache.hive.service.auth
 
org.apache.hive.service.cli - package org.apache.hive.service.cli
 
org.apache.hive.service.cli.operation - package org.apache.hive.service.cli.operation
 
org.apache.hive.service.cli.session - package org.apache.hive.service.cli.session
 
org.apache.hive.service.cli.thrift - package org.apache.hive.service.cli.thrift
 
org.apache.hive.service.server - package org.apache.hive.service.server
 
org.apache.hive.spark.client - package org.apache.hive.spark.client
 
org.apache.hive.spark.client.metrics - package org.apache.hive.spark.client.metrics
 
org.apache.hive.spark.client.rpc - package org.apache.hive.spark.client.rpc
 
org.apache.hive.spark.counter - package org.apache.hive.spark.counter
 
org.apache.hive.testutils.jdbc - package org.apache.hive.testutils.jdbc
 
org.apache.hive.testutils.junit.runners - package org.apache.hive.testutils.junit.runners
 
org.apache.hive.testutils.junit.runners.model - package org.apache.hive.testutils.junit.runners.model
 
ORIGINAL_LOCATION - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
originalBucketFilter - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
originalTableContainer - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
origProp - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
orReplace() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
othersDeletesAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
othersInsertsAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
othersUpdatesAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
out - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
out - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
out - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
outerPerBatchSetup(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
Do the per-batch setup for an outer join.
outExpr - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
outMap - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
outPath - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
outProtocol - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
Output - Interface in org.apache.hadoop.hive.contrib.mr
Collects output.
OUTPUT_CONFS_TO_SAVE - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
OUTPUT_FORMAT_STRING - Static variable in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
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
 
outputBatch - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
outputColumn - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
outputColumnNames - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
outputColumnNames - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
outputColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
outputDependencies(PrintStream, boolean, boolean, List<Task>) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
OutputFile - Class in org.apache.hive.beeline
 
OutputFile(String) - Constructor for class org.apache.hive.beeline.OutputFile
 
outputFileFormat(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for OutputFormat class.
outputformat(String) - Method in class org.apache.hive.beeline.Commands
 
OutputJobInfo - Class in org.apache.hive.hcatalog.mapreduce
The class used to serialize and store the output related information
outputObjInspector - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
outputOI - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
outputPartition - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
outputProjection - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
outputs - Variable in class org.apache.hadoop.hive.common.io.SortPrintStream
 
outputs - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
List of WriteEntities that are passed to the hooks.
outputs - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
outputs - Variable in class org.apache.hadoop.hive.ql.plan.DDLWork
List of WriteEntities that are passed to the hooks.
outputs - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
List of WriteEntities that are passed to the hooks.
outputStagePlans(PrintStream, List<Task>, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outputType - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Output type of the expression.
outputTypeNames - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
outputVectorAssignRowMap - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
outTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
overflowBatch - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
overflowRepeatedThreshold - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
OVERHEAD_PATH - Static variable in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
overhead_path - Variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
OVERRIDE_CLASSPATH - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
OVERRIDE_JARS_ENABLED - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
OVERRIDE_JARS_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
overrideJars() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
overrideJarsString() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
overwriteResults() - Method in class org.apache.hive.beeline.util.QFileClient
 
ownDeletesAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
owner() - Method in class org.apache.hive.hcatalog.api.HCatTable
Getter for table-owner.
owner(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for table-owner.
ownInsertsAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
ownUpdatesAreVisible(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 

P

P_COMPARE_CLASS - Static variable in class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
paddingTolerance(float) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Sets the tolerance for block padding as a percentage of stripe size.
Pair<T,U> - Class in org.apache.hive.hcatalog.data
Copy of C++ STL pair container.
Pair(T, U) - Constructor for class org.apache.hive.hcatalog.data.Pair
 
PamAuthenticationProviderImpl - Class in org.apache.hive.service.auth
 
PARAMETER_NAME - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
parameters(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatPartition
 
params - Variable in exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
parent - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
parent - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
parentConnections - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
parentEnd() - Method in interface org.apache.hadoop.hive.ql.io.parquet.convert.Repeated
 
parentEnd() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
parentEnd() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
parentId - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
parentLoader - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
parentOfRoot - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
parentOfRoot - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
parentOperators - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
parentSession - Variable in class org.apache.hive.service.cli.operation.Operation
 
parentStart() - Method in interface org.apache.hadoop.hive.ql.io.parquet.convert.Repeated
 
parentStart() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
parentStart() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
parentTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
PARQUET - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
PARQUET_COLUMN_INDEX_ACCESS - Static variable in class org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport
 
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
 
PARQUETFILE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
ParquetFileStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
ParquetFileStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.ParquetFileStorageFormatDescriptor
 
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
 
ParquetHiveRecord - Class in org.apache.hadoop.hive.serde2.io
This class wraps the object and object inspector that will be used later in DataWritableWriter class to get the object values.
ParquetHiveRecord() - Constructor for class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
ParquetHiveRecord(Object, StructObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
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, ParquetHiveRecord>, JobConf, String, Progressable, Properties) - 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() - Method in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
parse(String[]) - Method in class org.apache.hadoop.hive.common.cli.CommonCliOptions
Parse the arguments.
parse(String[]) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HiveMetastoreCli
 
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.
parse() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.SymbolParser
 
parseACLs(String) - Static method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
Parse comma separated list of ACL entries to secure generated nodes, e.g.
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.
parseByte(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyByte
Parses the string argument as if it was a byte value and returns the result.
parseByte(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyByte
Parses the string argument as if it was a byte value and returns the result.
parseColumnsMapping(String) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
parseColumnsMapping(String, boolean) - Static method in class org.apache.hadoop.hive.hbase.HBaseSerDe
Parses the HBase columns mapping specifier to identify the column families, qualifiers and also caches the byte arrays corresponding to them.
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, HashMap<TableScanOperator, ExprNodeDesc>, HashMap<TableScanOperator, PrunedPartitionList>, HashMap<String, Operator<? extends OperatorDesc>>, Set<JoinOperator>, Set<SMBMapJoinOperator>, List<LoadTableDesc>, List<LoadFileDesc>, Context, HashMap<String, String>, int, UnionProcContext, List<AbstractMapJoinOperator<? extends MapJoinDesc>>, 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>, BaseSemanticAnalyzer.AnalyzeRewriteContext, CreateTableDesc, QueryProperties) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
parseContext - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
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
 
ParseException - Exception in org.apache.hadoop.hive.serde2.dynamic_type
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parseHiveHistory(String, HiveHistory.Listener) - Static method in class org.apache.hadoop.hive.ql.history.HiveHistoryUtil
Parses history file and calls call back functions.
parseInt(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyInteger
Parses the string argument as if it was an int value and returns the result.
parseInt(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyInteger
Parses the string argument as if it was an int value and returns the result.
parseInto(DateTimeParserBucket, String, int) - Method in class org.apache.hive.common.util.TimestampParser.MillisDateFormatParser
 
parseLong(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyLong
Parses the string argument as if it was a long value and returns the result.
parseLong(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyLong
Parses the string argument as if it was an long value and returns the result.
parseMapping(String) - Static method in class org.apache.hadoop.hive.accumulo.columns.ColumnMappingFactory
Consumes the column mapping specification and breaks it into column family and column qualifier.
parseMultiDelimit(byte[], byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
parseNumericValueWithRange(String, String, int, int) - Static method in class org.apache.hive.common.util.DateUtils
 
parsePrimitiveParts(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Make some of the TypeInfo parsing available as a utility.
parsePrivObject(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
PARSER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
parser - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
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
 
parseShort(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyShort
Parses the string argument as if it was a short value and returns the result.
parseShort(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyShort
Parses the string argument as if it was a short value and returns the result.
parseTimestamp(String) - Method in class org.apache.hive.common.util.TimestampParser
Parse the input string and return a timestamp value
parseURL(String) - Static method in class org.apache.hive.jdbc.Utils
Parse JDBC connection URL The new format of the URL is: jdbc:hive2://:,:/dbName;sess_var_list?hive_conf_list#hive_var_list where the optional sess, conf and var lists are semicolon separated = pairs.
ParseUtils - Class in org.apache.hadoop.hive.ql.parse
Library of utility functions used in the parse code.
PART_STAT_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hive.hbase.HBaseStatsSetupConstants
 
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.hbase.HBaseStatsSetupConstants
 
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.hbase.HBaseStatsSetupConstants
 
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.hbase.HBaseStatsSetupConstants
 
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
 
partCol(HCatFieldSchema) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for individual partition columns.
partCols(List<HCatFieldSchema>) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
partCols(List<HCatFieldSchema>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for list of partition columns.
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
 
partialCopyToStandardObject(List<Object>, Object, int, int, StructObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Copy specified fields in the input row to the output array of standard objects.
partialResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
partialResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
partialscan - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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
 
PartInfo - Class in org.apache.hive.hcatalog.mapreduce
The Class used to serialize the partition information read from the metadata server that maps to a partition.
PartInfo(HCatSchema, HiveStorageHandler, String, Properties, Map<String, String>, HCatTableInfo) - Constructor for class org.apache.hive.hcatalog.mapreduce.PartInfo
Instantiates a new hcat partition info.
Partition - Class in org.apache.hadoop.hive.metastore.api
 
Partition() - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
 
Partition(List<String>, String, String, int, int, StorageDescriptor, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
 
Partition(Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
Performs a deep copy on other.
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 - Variable in class org.apache.hive.hcatalog.templeton.PartitionDesc
 
Partition._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PARTITION_DATE_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore
A fixed date format to be used for hive partition column values.
partition_name_has_valid_characters(List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
partition_name_has_valid_characters(List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
partition_name_has_valid_characters(List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
partition_name_has_valid_characters(List<String>, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
partition_name_has_valid_characters(List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
partition_name_to_spec(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
partition_name_to_spec(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
partition_name_to_spec(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
partition_name_to_vals(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
partition_name_to_vals(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
partition_name_to_vals(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
PARTITION_RETRIEVING - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
partitionByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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
 
PartitionCreationFailed - Exception in org.apache.hive.hcatalog.streaming
 
PartitionCreationFailed(HiveEndPoint, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.PartitionCreationFailed
 
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
 
PartitionDesc - Class in org.apache.hive.hcatalog.templeton
A description of the partition to create.
PartitionDesc() - Constructor for class org.apache.hive.hcatalog.templeton.PartitionDesc
 
partitionDescriptor(Map<String, String>) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
 
PartitionDropOptions - Class in org.apache.hadoop.hive.metastore
Class to generalize the switches for dropPartitions().
PartitionDropOptions() - Constructor for class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
partitionedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
partitionedTableFunction() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionedTableFunction() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
PartitionedTableFunctionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PartitionedTableFunctionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
partitionEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
The evaluators for the partition columns (CLUSTER BY or DISTRIBUTE BY in Hive language).
PartitionEventType - Enum in org.apache.hadoop.hive.metastore.api
 
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
 
PartitionExpressionProxy - Interface in org.apache.hadoop.hive.metastore
The proxy interface that metastore uses to manipulate and apply serialized filter expressions coming from client.
partitioningSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitioningSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
PartitionIterable - Class in org.apache.hadoop.hive.ql.metadata
PartitionIterable - effectively a lazy Iterable Sometimes, we have a need for iterating through a list of partitions, but the list of partitions can be too big to fetch as a single object.
PartitionIterable(List<Partition>) - Constructor for class org.apache.hadoop.hive.ql.metadata.PartitionIterable
Dummy constructor, which simply acts as an iterator on an already-present list of partitions, allows for easy drop-in replacement for other methods that already have a List
PartitionIterable(Hive, Table, Map<String, String>, int) - Constructor for class org.apache.hadoop.hive.ql.metadata.PartitionIterable
Primary constructor that fetches all partitions in a given table, given a Hive object and a table object, and a partial partition spec.
PartitionKeySampler - Class in org.apache.hadoop.hive.ql.exec
 
PartitionKeySampler() - Constructor for class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
PartitionListComposingSpec - Class in org.apache.hadoop.hive.metastore.api
 
PartitionListComposingSpec() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
PartitionListComposingSpec(List<Partition>) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
PartitionListComposingSpec(PartitionListComposingSpec) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
Performs a deep copy on other.
PartitionListComposingSpec._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionListComposingSpecProxy - Class in org.apache.hadoop.hive.metastore.partition.spec
PartitionSpecProxy implementation that composes a List of Partitions.
PartitionListComposingSpecProxy(PartitionSpec) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
PartitionListComposingSpecProxy.Iterator - Class in org.apache.hadoop.hive.metastore.partition.spec
 
PartitionListComposingSpecProxy.Iterator(PartitionListComposingSpecProxy) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
partitionLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionNameHasValidCharacters(List<String>, Pattern) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
partitionNameToSpec(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
partitionNameToSpec(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
partitionNameToVals(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
partitionNameToVals(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
PartitionPrune - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
PartitionPrune() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune
 
PartitionPrune.ExtractPartPruningPredicate - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
PartitionPrune.ExtractPartPruningPredicate(RelOptCluster, RelOptHiveTable) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractPartPruningPredicate
 
PartitionPrune.ExtractRemainingPredicate - Class in org.apache.hadoop.hive.ql.optimizer.calcite.rules
 
PartitionPrune.ExtractRemainingPredicate(RelOptCluster, RexNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractRemainingPredicate
 
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
 
PartitionsByExprRequest - Class in org.apache.hadoop.hive.metastore.api
 
PartitionsByExprRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
PartitionsByExprRequest(String, String, ByteBuffer) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
PartitionsByExprRequest(PartitionsByExprRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
Performs a deep copy on other.
PartitionsByExprRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionsByExprResult - Class in org.apache.hadoop.hive.metastore.api
 
PartitionsByExprResult() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
PartitionsByExprResult(List<Partition>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
PartitionsByExprResult(PartitionsByExprResult) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
Performs a deep copy on other.
PartitionsByExprResult._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionSpec - Class in org.apache.hadoop.hive.metastore.api
 
PartitionSpec() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
PartitionSpec(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
PartitionSpec(PartitionSpec) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpec
Performs a deep copy on other.
partitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
PartitionSpec._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionSpecProxy - Class in org.apache.hadoop.hive.metastore.partition.spec
Polymorphic proxy class, equivalent to org.apache.hadoop.hive.metastore.api.PartitionSpec.
PartitionSpecProxy() - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
 
partitionSpecProxy - Variable in class org.apache.hive.hcatalog.api.HCatPartitionSpec
 
PartitionSpecProxy.Factory - Class in org.apache.hadoop.hive.metastore.partition.spec
Factory to construct PartitionSetProxy instances, from PartitionSets.
PartitionSpecProxy.Factory() - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.Factory
 
PartitionSpecProxy.PartitionIterator - Interface in org.apache.hadoop.hive.metastore.partition.spec
Iterator to iterate over Partitions corresponding to a PartitionSpec.
PartitionSpecProxy.SimplePartitionWrapperIterator - Class in org.apache.hadoop.hive.metastore.partition.spec
Simple wrapper class for pre-constructed Partitions, to expose a PartitionIterator interface, where the iterator-sequence consists of just one Partition.
PartitionSpecProxy.SimplePartitionWrapperIterator(Partition) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
PartitionSpecWithSharedSD - Class in org.apache.hadoop.hive.metastore.api
 
PartitionSpecWithSharedSD() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
PartitionSpecWithSharedSD(List<PartitionWithoutSD>, StorageDescriptor) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
PartitionSpecWithSharedSD(PartitionSpecWithSharedSD) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
Performs a deep copy on other.
PartitionSpecWithSharedSD._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionSpecWithSharedSDProxy - Class in org.apache.hadoop.hive.metastore.partition.spec
Subclass of PartitionSpecProxy that pulls out commonality of StorageDescriptor properties within a Partition-list into a common StorageDescriptor instance.
PartitionSpecWithSharedSDProxy(PartitionSpec) - Constructor for class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
PartitionSpecWithSharedSDProxy.Iterator - Class in org.apache.hadoop.hive.metastore.partition.spec
Iterator implementation to iterate over all Partitions within the PartitionSpecWithSharedSDProxy.
PartitionsStatsRequest - Class in org.apache.hadoop.hive.metastore.api
 
PartitionsStatsRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
PartitionsStatsRequest(String, String, List<String>, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
PartitionsStatsRequest(PartitionsStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
Performs a deep copy on other.
PartitionsStatsRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionsStatsResult - Class in org.apache.hadoop.hive.metastore.api
 
PartitionsStatsResult() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
PartitionsStatsResult(Map<String, List<ColumnStatisticsObj>>) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
PartitionsStatsResult(PartitionsStatsResult) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
Performs a deep copy on other.
PartitionsStatsResult._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PartitionTableFunctionDescription - Annotation Type in org.apache.hadoop.hive.ql.exec
 
partitionTableFunctionSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionTableFunctionSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
partitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
partitionVals - Variable in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
PartitionWithoutSD - Class in org.apache.hadoop.hive.metastore.api
 
PartitionWithoutSD() - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
PartitionWithoutSD(List<String>, int, int, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
PartitionWithoutSD(PartitionWithoutSD) - Constructor for class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
Performs a deep copy on other.
PartitionWithoutSD._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
partName - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
partSpec - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.TableSpec
 
partTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
passExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Pass the execContext reference to every child operator
PasswdAuthenticationProvider - Interface in org.apache.hive.service.auth
 
path - Variable in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
PATHATTR_NAME - Static variable in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
pathid - Variable in class org.apache.hadoop.hive.ql.Context
 
pathToPartitionInfo - Variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
PatternOrIdentifier - Class in org.apache.hive.service.cli
PatternOrIdentifier.
PatternOrIdentifier(String) - Constructor for class org.apache.hive.service.cli.PatternOrIdentifier
 
patternToRegex(String) - Static method in class org.apache.hive.service.cli.CLIServiceUtils
Convert a SQL search pattern into an equivalent Java Regex.
pComparisonKeyset() - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
 
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
 
peek() - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
peekNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
percentComplete - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
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 - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
perfLogger - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
PerfLogger - Class in org.apache.hadoop.hive.ql.log
PerfLogger.
PerfLogger() - Constructor for class org.apache.hadoop.hive.ql.log.PerfLogger
 
perfLogger - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
perform(RelOptRuleCall, Filter, HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePartitionPruneRule
 
performOp(byte[], byte[], byte[], int, Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad
 
performOp(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseTrim
 
performOp(byte[], byte[], byte[], int, Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLpad
 
performOp(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLTrim
 
performOp(byte[], byte[], byte[], int, Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRpad
 
performOp(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRTrim
 
performOp(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTrim
 
performValueExpressions(VectorizedRowBatch, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
permissions - Variable in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
persist(ObjectOutputStream, MapJoinPersistableTableContainer) - 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
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagate
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.GroupByProcessor
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.JoinProcessor
 
physicalContext - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
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
 
pig(String, String, List<String>, String, String, String, boolean, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.Server
Run a Pig job.
PIG_ARCHIVE_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
PIG_COMPLETE - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
PIG_ID - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
PIG_OPTS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants.PigConstants
 
PIG_PATH_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
pigArchive() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
PigDelegator - Class in org.apache.hive.hcatalog.templeton
Submit a Pig job.
PigDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.PigDelegator
 
pigPath() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
pigVersion() - Method in class org.apache.hive.hcatalog.templeton.Server
Get version of pig software being run by this WebHCat server
pivotResult(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
PLAIN_METHOD - Static variable in class org.apache.hive.service.auth.PlainSaslServer
 
PlainSaslHelper - Class in org.apache.hive.service.auth
 
PlainSaslHelper.PlainCallbackHandler - Class in org.apache.hive.service.auth
 
PlainSaslHelper.PlainCallbackHandler(String, String) - Constructor for class org.apache.hive.service.auth.PlainSaslHelper.PlainCallbackHandler
 
PlainSaslServer - Class in org.apache.hive.service.auth
Sun JDK only provides a PLAIN client and no server.
PlainSaslServer.SaslPlainProvider - Class in org.apache.hive.service.auth
 
PlainSaslServer.SaslPlainProvider() - Constructor for class org.apache.hive.service.auth.PlainSaslServer.SaslPlainProvider
 
PlainSaslServer.SaslPlainServerFactory - Class in org.apache.hive.service.auth
 
PlainSaslServer.SaslPlainServerFactory() - Constructor for class org.apache.hive.service.auth.PlainSaslServer.SaslPlainServerFactory
 
PlanModifierForASTConv - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
PlanModifierForASTConv() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForASTConv
 
PlanModifierForReturnPath - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
PlanModifierForReturnPath() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForReturnPath
 
PlanModifierUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
PlanModifierUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierUtil
 
PlanUtils - Class in org.apache.hadoop.hive.ql.plan
PlanUtils.
PlanUtils.ExpressionTypes - Enum in org.apache.hadoop.hive.ql.plan
ExpressionTypes.
PLOG - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
plus(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
plusOpType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
POLL_JOBPROGRESS_MSEC - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
pollFinished() - Method in class org.apache.hadoop.hive.ql.DriverContext
Polls running tasks to see if a task has ended.
popMsg(RecognizerSharedState) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
popNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
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
 
populateQuickStats(FileStatus[], Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
populateValue(WriteBuffers.ByteSegmentRef) - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Take the segment reference from #getValueRefs(byte[], int, List) result and makes it self-contained - adds byte array where the value is stored, and updates the offset from "global" write buffers offset to offset within that array.
populateValue(WriteBuffers.ByteSegmentRef) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Changes the byte segment reference from being a reference to global buffer to the one with a self-contained byte array.
populateVirtualColumnValues(ExecMapperContext, List<VirtualColumn>, Object[], Deserializer) - Static method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
PORT - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
portNum - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
posBigTable - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
PositionProvider - Interface in org.apache.hadoop.hive.ql.io.orc
An interface used for seeking to a row index.
POSITIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
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
 
posSingleVectorMapJoinSmallTable - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
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).
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzer
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzerBase
 
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
 
POSTGRES_SKIP_STANDARD_STRINGS_DBOPT - Static variable in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
POSTGRES_STANDARD_STRINGS_OPT - Static variable in class org.apache.hive.beeline.HiveSchemaHelper.PostgresCommandParser
 
postHook(Set<String>, List<String>) - Method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
 
POUND - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
pow(int) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
powAsDouble(double) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Calculate the power of this value in double precision.
POWER_FIVES_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^x.
POWER_FIVES_INT31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^x.
POWER_FIVES_INT63 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5^x.
POWER_TENS_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
10^x.
POWER_TENS_INT31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
10^x.
PRE_HOOK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
PreAddIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAddIndexEvent(Index, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAddIndexEvent
 
PreAddPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAddPartitionEvent(Table, List<Partition>, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
 
PreAddPartitionEvent(Table, Partition, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
 
PreAddPartitionEvent(Table, PartitionSpecProxy, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAddPartitionEvent
Alternative constructor, using
PreAlterIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAlterIndexEvent(Index, Index, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAlterIndexEvent
 
PreAlterPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAlterPartitionEvent(String, String, List<String>, Partition, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAlterPartitionEvent
 
PreAlterTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAlterTableEvent(Table, Table, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAlterTableEvent
 
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.
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class org.apache.hive.hcatalog.cli.SemanticAnalysis.HCatSemanticAnalyzer
 
PreAuthorizationCallEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreAuthorizationCallEvent(HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreAuthorizationCallEvent
 
precedenceAmpersandExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAmpersandExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceAmpersandOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAmpersandOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceAndExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAndExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceAndOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAndOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceBitwiseOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceBitwiseOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceBitwiseXorExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseXorExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceBitwiseXorOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseXorOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceEqualExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceEqualExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceEqualNegatableOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceEqualNegatableOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceEqualOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceEqualOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceFieldExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceFieldExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceNotExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceNotExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceNotOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceNotOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedencePlusExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedencePlusExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedencePlusOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedencePlusOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceStarExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceStarExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceStarOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceStarOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceUnaryOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnaryOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceUnaryPrefixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnaryPrefixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
precedenceUnarySuffixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnarySuffixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
preceedingWork - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
preceedingWork - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
precision() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
Returns the number of digits (integer and fractional) in the number, which is equivalent to SQL decimal precision.
precision - Variable in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Default implementation.
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantByteObjectInspector
 
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveDecimalObjectInspector
 
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantIntObjectInspector
 
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantLongObjectInspector
 
precision() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantShortObjectInspector
 
precision() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
The precision of the underlying data.
precision() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
PRECISION - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
PRECISION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
PRECISION_TO_BYTE_COUNT - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
PreCreateDatabaseEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreCreateDatabaseEvent(Database, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreCreateDatabaseEvent
 
preCreateTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
preCreateTable(Table) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
preCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called before a new table definition is added to the metastore during CREATE TABLE.
PreCreateTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreCreateTableEvent(Table, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreCreateTableEvent
 
predicateHandler - Variable in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
predicateHandler - Variable in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
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
 
PreDropDatabaseEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreDropDatabaseEvent(Database, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreDropDatabaseEvent
 
PreDropIndexEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreDropIndexEvent(Index, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreDropIndexEvent
 
PreDropPartitionEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreDropPartitionEvent(Table, Partition, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreDropPartitionEvent
 
preDropTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
preDropTable(Table) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
preDropTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called before a table definition is removed from the metastore during DROP TABLE.
PreDropTableEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreDropTableEvent(Table, boolean, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreDropTableEvent
 
PreEventContext - Class in org.apache.hadoop.hive.metastore.events
Base class for all the events which are defined for metastore.
PreEventContext(PreEventContext.PreEventType, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreEventContext
 
PreEventContext.PreEventType - Enum in org.apache.hadoop.hive.metastore.events
 
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
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.AbstractPrimitiveLazyObjectInspector
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
preferWritable() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Whether the ObjectInspector prefers to return a Primitive Writable Object instead of a Primitive Java Object.
prefixBy(PTFInvocationSpec.PartitionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
prefixString(List<Boolean>) - Static method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
prefixString(List<Boolean>, String) - Static method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
preFooterWrite(OrcFile.WriterContext) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterCallback
 
preHook(Set<String>, List<String>) - Method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
 
PreLoadPartitionDoneEvent - Class in org.apache.hadoop.hive.metastore.events
 
PreLoadPartitionDoneEvent(String, String, Map<String, String>, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreLoadPartitionDoneEvent
 
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
 
prepare(HiveConf) - Method in class org.apache.hive.service.cli.operation.SQLOperation
Compile the query and extract metadata
prepareCall(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareCall(String, int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareCall(String, int, int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareConstant() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
prepareExpr(ExprNodeGenericFuncDesc, List<String>, List<PrimitiveTypeInfo>) - 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
prepareForReading() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
prepareForWrite(RecordConsumer) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
prepareJobOutput(JobConf) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Hive uses side effect files exclusively for it's output.
prepareRead() - Method in class org.apache.hive.hcatalog.data.transfer.HCatReader
This should be called at master node to obtain ReaderContext which then should be serialized and sent to slave nodes.
prepareRead() - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatInputFormatReader
 
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
 
prepareStatement(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareStatement(String, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareStatement(String, int[]) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareStatement(String, String[]) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareStatement(String, int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareStatement(String, int, int, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
prepareWithRetry(Connection, String, long, 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).
prepareWrite() - Method in class org.apache.hive.hcatalog.data.transfer.HCatWriter
External system should invoke this method exactly once from a master node.
prepareWrite() - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
prepDb() - Static method in class org.apache.hadoop.hive.metastore.txn.TxnDbUtil
 
prependPathComponent(String) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Appends the specified component to the path list.
PreReadDatabaseEvent - Class in org.apache.hadoop.hive.metastore.events
Database read event
PreReadDatabaseEvent(Database, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreReadDatabaseEvent
 
PreReadTableEvent - Class in org.apache.hadoop.hive.metastore.events
Table read event
PreReadTableEvent(Table, HiveMetaStore.HMSHandler) - Constructor for class org.apache.hadoop.hive.metastore.events.PreReadTableEvent
 
present - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
 
PRESENT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
PRESENT = 0;
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
 
prev - Variable in class org.apache.hadoop.hive.common.DiskRangeList
 
prevCharIsCR - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
prevCharIsLF - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
previous() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
primarykeys(String) - Method in class org.apache.hive.beeline.Commands
 
primaryPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
primarySeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The separators for this instance.
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
 
PRIMITIVE_TYPES - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
primitiveCategory - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
The category of the PrimitiveType.
PrimitiveComparison - Interface in org.apache.hadoop.hive.accumulo.predicate.compare
Wraps type-specific comparison operations over a constant value.
PrimitiveComparisonFilter - Class in org.apache.hadoop.hive.accumulo.predicate
Operates over a single qualifier.
PrimitiveComparisonFilter() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.PrimitiveComparisonFilter
 
primitiveEntry(TPrimitiveTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
primitiveJavaClass - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
primitiveJavaClass refers to java classes like Integer, Double, String etc.
primitiveJavaType - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
primitiveJavaType refers to java types like int, double, etc.
primitiveJavaTypeToClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Return Whether the class is a Java Primitive type or a Java Primitive class.
PrimitiveObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
PrimitiveObjectInspector.
PrimitiveObjectInspector.PrimitiveCategory - Enum in org.apache.hadoop.hive.serde2.objectinspector
The primitive types supported by Hive.
PrimitiveObjectInspectorConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
PrimitiveObjectInspectorConverter.
PrimitiveObjectInspectorConverter() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter
 
PrimitiveObjectInspectorConverter.BinaryConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.BinaryConverter(PrimitiveObjectInspector, SettableBinaryObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.BinaryConverter
 
PrimitiveObjectInspectorConverter.BooleanConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the byte type.
PrimitiveObjectInspectorConverter.BooleanConverter(PrimitiveObjectInspector, SettableBooleanObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.BooleanConverter
 
PrimitiveObjectInspectorConverter.ByteConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the byte type.
PrimitiveObjectInspectorConverter.ByteConverter(PrimitiveObjectInspector, SettableByteObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.ByteConverter
 
PrimitiveObjectInspectorConverter.DateConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.DateConverter(PrimitiveObjectInspector, SettableDateObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.DateConverter
 
PrimitiveObjectInspectorConverter.DoubleConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the double type.
PrimitiveObjectInspectorConverter.DoubleConverter(PrimitiveObjectInspector, SettableDoubleObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.DoubleConverter
 
PrimitiveObjectInspectorConverter.FloatConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the float type.
PrimitiveObjectInspectorConverter.FloatConverter(PrimitiveObjectInspector, SettableFloatObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.FloatConverter
 
PrimitiveObjectInspectorConverter.HiveCharConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.HiveCharConverter(PrimitiveObjectInspector, SettableHiveCharObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveCharConverter
 
PrimitiveObjectInspectorConverter.HiveDecimalConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.HiveDecimalConverter(PrimitiveObjectInspector, SettableHiveDecimalObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveDecimalConverter
 
PrimitiveObjectInspectorConverter.HiveIntervalDayTimeConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.HiveIntervalDayTimeConverter(PrimitiveObjectInspector, SettableHiveIntervalDayTimeObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveIntervalDayTimeConverter
 
PrimitiveObjectInspectorConverter.HiveIntervalYearMonthConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.HiveIntervalYearMonthConverter(PrimitiveObjectInspector, SettableHiveIntervalYearMonthObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveIntervalYearMonthConverter
 
PrimitiveObjectInspectorConverter.HiveVarcharConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.HiveVarcharConverter(PrimitiveObjectInspector, SettableHiveVarcharObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.HiveVarcharConverter
 
PrimitiveObjectInspectorConverter.IntConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the int type.
PrimitiveObjectInspectorConverter.IntConverter(PrimitiveObjectInspector, SettableIntObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.IntConverter
 
PrimitiveObjectInspectorConverter.LongConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the long type.
PrimitiveObjectInspectorConverter.LongConverter(PrimitiveObjectInspector, SettableLongObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.LongConverter
 
PrimitiveObjectInspectorConverter.ShortConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A converter for the short type.
PrimitiveObjectInspectorConverter.ShortConverter(PrimitiveObjectInspector, SettableShortObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.ShortConverter
 
PrimitiveObjectInspectorConverter.StringConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A helper class to convert any primitive to String.
PrimitiveObjectInspectorConverter.StringConverter(PrimitiveObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.StringConverter
 
PrimitiveObjectInspectorConverter.TextConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A helper class to convert any primitive to Text.
PrimitiveObjectInspectorConverter.TextConverter(PrimitiveObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TextConverter
 
PrimitiveObjectInspectorConverter.TimestampConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
PrimitiveObjectInspectorConverter.TimestampConverter(PrimitiveObjectInspector, SettableTimestampObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TimestampConverter
 
PrimitiveObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
PrimitiveObjectInspectorFactory is the primary way to create new PrimitiveObjectInspector instances.
PrimitiveObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
PrimitiveObjectInspectorUtils.PrimitiveGrouping - Enum in org.apache.hadoop.hive.serde2.objectinspector.primitive
Provide a general grouping for each primitive data type.
PrimitiveObjectInspectorUtils.PrimitiveTypeEntry - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
TypeEntry stores information about a Hive Primitive TypeInfo.
PrimitiveObjectInspectorUtils.PrimitiveTypeEntry() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
PRIMITIVES1 - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
PRIMITIVES2 - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
primitiveType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrimitiveTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
There are limited number of Primitive Types.
PrimitiveTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
For java serialization use only.
primitiveTypeInfos() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
primitiveTypeInfos() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
primitiveTypeInfos() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
primitiveTypeInfos() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
primitiveTypeInfosFromStructObjectInspector(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
primitiveTypeInfosFromTypeNames(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
PrimitiveTypes - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
primitiveWritableClass - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
writableClass refers to hadoop Writable classes like IntWritable, DoubleWritable, Text etc.
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
 
principalIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
principalIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
principalName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrincipalPrivilegeSet - Class in org.apache.hadoop.hive.metastore.api
 
PrincipalPrivilegeSet() - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
PrincipalPrivilegeSet(Map<String, List<PrivilegeGrantInfo>>, Map<String, List<PrivilegeGrantInfo>>, Map<String, List<PrivilegeGrantInfo>>) - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
PrincipalPrivilegeSet(PrincipalPrivilegeSet) - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Performs a deep copy on other.
PrincipalPrivilegeSet._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
principalSpecification() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrincipalType - Enum in org.apache.hadoop.hive.metastore.api
 
print(JSONObject, PrintStream) - Method in interface org.apache.hadoop.hive.common.jsonexplain.JsonParser
 
print(PrintStream, List<Boolean>, boolean) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Op
 
print(PrintStream, List<Boolean>) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Stage
 
print(JSONObject, PrintStream) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
print(PrintStream, List<Boolean>, String, Vertex) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
print(String) - Method in class org.apache.hive.beeline.OutputFile
 
printDirect(String) - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
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
 
println(String) - Method in class org.apache.hadoop.hive.common.io.CachingPrintStream
 
println(String) - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
println(String) - Method in class org.apache.hive.beeline.OutputFile
 
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
 
printSet - Static variable in class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
printUsage() - Method in class org.apache.hadoop.hive.common.cli.CommonCliOptions
Print usage information for the CLI.
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
 
PrivilegeBag - Class in org.apache.hadoop.hive.metastore.api
 
PrivilegeBag() - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
PrivilegeBag(List<HiveObjectPrivilege>) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
PrivilegeBag(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Performs a deep copy on other.
PrivilegeBag._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
PrivilegeGrantInfo - Class in org.apache.hadoop.hive.metastore.api
 
PrivilegeGrantInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
PrivilegeGrantInfo(String, int, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
PrivilegeGrantInfo(PrivilegeGrantInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Performs a deep copy on other.
PrivilegeGrantInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
privilegeIncludeColObject() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privilegeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privilegeObject() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrivilegeType - Enum in org.apache.hadoop.hive.ql.security.authorization
Privilege type
privlegeDef() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privObject() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privObjectCols() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
prjColIDs - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarStructBase
 
procedures(String) - Method in class org.apache.hive.beeline.Commands
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
process(String) - Method in class org.apache.hadoop.hive.common.io.DigestPrintStream
 
process(String) - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
process(String) - Method in class org.apache.hadoop.hive.common.io.SortPrintStream
 
process(Object[]) - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFCount2
 
process(Object[]) - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFExplode2
 
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.TSetIpAddressProcessor
 
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.TUGIBasedProcessor
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
process(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.
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
process(Writable) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
process(Object) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator.Handler
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Process the row.
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.OrcFileMergeOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
process(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.
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.TezDummyStoreOperator
Unlike the MR counterpoint, on Tez we want processOp to forward the records.
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyLongOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyMultiKeyOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyStringOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerLongOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerMultiKeyOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerStringOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiLongOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiMultiKeyOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiStringOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterLongOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterMultiKeyOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterStringOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorLimitOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator
 
process(Writable) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
process(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
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(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.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondColumnExprProcessor
 
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.ColumnPrunerLimitProc
 
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.ColumnPrunerScriptProc
 
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.ConstantPropagateProcFactory.ConstantPropagateDefaultProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateFileSinkProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateFilterProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateGroupByProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateReduceSinkProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateSelectProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateStopProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory.ConstantPropagateTableScanProc
 
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(ReduceSinkOperator, ReduceSinkDeDuplication.ReduceSinkDeduplicateProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
process(ReduceSinkOperator, GroupByOperator, ReduceSinkDeDuplication.ReduceSinkDeduplicateProcCtx) - 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.DynamicPartitionPruningOptimization.DynamicPartitionPrunerProc
process simply remembers all the dynamic partition pruning expressions found
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.DynamicPartitionPruningOptimization
 
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.MergeJoinProc
 
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.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.CrossProductCheck.ExtractReduceSinkInfo
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck.MapJoinCheck
 
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.RemoveDynamicPruningBySize
 
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.spark.SetSparkReducerParallelism
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinHintOptimizer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinOptimizer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkMapJoinOptimizer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc.SparkMapJoinFollowedByGroupByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinProcFactory.SparkSkewJoinJoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSMBJoinHintOptimizer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinOptimizer
 
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.ReduceSinkStatsRule
 
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.AppMasterEventProcessor
 
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.spark.GenSparkWork
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkFileSinkProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkProcessAnalyzeTable
 
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.DateTimeExprProcessor
 
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.IntervalExprProcessor
 
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.parse.UnionProcessor
 
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.PTFPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.ReduceSinkPPD
 
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
 
process(WatchedEvent) - Method in class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper.DummyWatcher
 
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server.TUGIAssumingProcessor
 
process(HttpRequest, HttpContext) - Method in class org.apache.hive.jdbc.HttpRequestInterceptorBase
 
process(WatchedEvent) - Method in class org.apache.hive.jdbc.ZooKeeperHiveClientHelper.DummyWatcher
 
process(TProtocol, TProtocol) - Method in class org.apache.hive.service.auth.TSetIpAddressProcessor
 
process_stage1(String[]) - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
process_stage2(CliSessionState) - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
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
processAndOpNode(Node, Object[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
processAppMasterEvent(GenTezProcContext, AppMasterEventOperator) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
processAppMasterEvent sets up the event descriptor and the MapWork.
processCmd(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processCmd(String) - Method in class org.apache.hadoop.hive.common.cli.HiveFileProcessor
define the processor for each Hive command supported by Hive
processColumnDesc(NodeProcessorCtx, ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcFactory.LBPRColumnExprProcessor
 
processColumnDesc(NodeProcessorCtx, ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.PPRColumnExprProcessor
 
processColumnDesc(NodeProcessorCtx, ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.ColumnExprProcessor
Process column desc.
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
 
processedAllRows() - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
processExpression(ExprNodeGenericFuncDesc, Object[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
processFile(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processFile(String) - Method in class org.apache.hadoop.hive.common.cli.HiveFileProcessor
 
processFile(String) - Method in interface org.apache.hadoop.hive.common.cli.IHiveFileProcessor
Parse the file and execute the Hive commands in it.
processFileSink(GenTezProcContext, FileSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
processFileSink(GenSparkProcContext, FileSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
processFinal() - Method in class org.apache.hadoop.hive.common.io.DigestPrintStream
 
processFinal() - Method in class org.apache.hadoop.hive.common.io.FetchConverter
 
processFinal() - Method in class org.apache.hadoop.hive.common.io.SortAndDigestPrintStream
 
processFinal() - Method in class org.apache.hadoop.hive.common.io.SortPrintStream
 
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
 
processGroupBy(GroupByOptimizer.GroupByOptimizerContext, Stack<Node>, GroupByOperator, int) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
processGroupBy(Operator<? extends OperatorDesc>, GroupByOperator, BucketingSortingCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.GroupByInferrer
Process a GroupByOperator to determine which if any columns the output is bucketed and sorted by, assumes the columns output by the parent which are bucketed and sorted have already been determined.
processGroupByReduceSink(ReduceSinkOperator, GroupByOperator, BucketingSortingCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.GroupByInferrer
Process the ReduceSinkOperator preceding a GroupByOperator to determine which columns are bucketed and sorted.
processingDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
 
processingDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunctionResultList
 
processingDone() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunctionResultList
 
processInitFiles(CliSessionState) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processLine(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processLine(String, boolean) - Method in class org.apache.hadoop.hive.cli.CliDriver
Processes a line of semicolon separated commands
processLine(String) - Method in class org.apache.hadoop.hive.common.cli.HiveFileProcessor
process the Hive command by lines
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
 
processNextRecord(T) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList
Process the given record.
processNextRecord(Tuple2<BytesWritable, BytesWritable>) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveMapFunctionResultList
 
processNextRecord(Tuple2<HiveKey, Iterable<BytesWritable>>) - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveReduceFunctionResultList
 
processNoScanCommand(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
process analyze ...
processOption(String, ListIterator) - Method in class org.apache.hive.beeline.BeeLine.BeelineParser
 
processorContext - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
processorContext - Variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
processOrOpNode(Node, Object[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloRangeGenerator
 
processPartialScanCommand(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
process analyze ...
processPayload(ByteBuffer, String) - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
processQualifiedColRef(TypeCheckCtx, ASTNode, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor
 
processQualifiedColRef(TypeCheckCtx, ASTNode, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
processReader(BufferedReader) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processReader(BufferedReader) - Method in class org.apache.hadoop.hive.common.cli.HiveFileProcessor
execute the buffered reader which stores the commands
processRow(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMapRecordHandler
 
processRow(Object, Iterator<E>) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMapRecordHandler
 
processRow(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
processRow(Object, Iterator<E>) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
processRow(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
Process row with key and single value.
processRow(Object, Iterator<E>) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
Process row with key and value collection.
processRow(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
processRow(Object, Iterator<E>) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
processRow(Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopStreaming
 
processRow(Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMapStreaming
 
processRow(Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
processRow(Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
processRowSkewedIndex(RowSchema) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
Match column in skewed column list and record position.
processSelectDatabase(CliSessionState) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processSkewJoin(JoinOperator, Task<? extends Serializable>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenMRSkewJoinProcessor
Create tasks for processing skew joins.
processSkewJoin(JoinOperator, Task<? extends Serializable>, ReduceWork, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenSparkSkewJoinProcessor
 
processStorageFormat(String) - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
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.
processVectorInspector(StructObjectInspector, VectorExpressionWriterFactory.SingleOIDClosure) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Creates the value writers for an struct object inspector.
processVertex(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
profile - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
progress(RunningJob, JobClient, HiveTxnManager) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
progress() - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
progress - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
progress - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
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
 
project(ImmutableBitSet, Set<RelDataTypeField>, RelFactories.ProjectFactory) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
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
 
projectMapping(RelNode, Mapping, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject
Creates a relational expression which projects the output fields of a relational expression according to a partial mapping.
projectNonColumnEquiConditions(RelFactories.ProjectFactory, RelNode[], List<RexNode>, List<RexNode>, int, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
Push any equi join conditions that are not column references as Projections on top of the children.
prompt - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
prompt2 - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
prop - Variable in class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
propagatableUdfs - Static variable in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
 
propagateNullsColCol(ColumnVector, ColumnVector, ColumnVector, int[], int, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
 
properties - Variable in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
properties - Variable in class org.apache.hadoop.hive.hbase.AbstractHBaseKeyFactory
 
properties - Variable in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
properties(String) - Method in class org.apache.hive.beeline.Commands
Connect to the database defined in the specified properties file.
properties - Variable in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
properties - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.SerdeDesc
 
properties - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.StoredByDesc
 
property - Variable in class org.apache.hadoop.hive.ant.GetVersionPref
The name of the property that gets the version prefix.
PropValueUnion - Class in org.apache.hadoop.hive.serde2.thrift.test
 
PropValueUnion() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
PropValueUnion(PropValueUnion._Fields, Object) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
PropValueUnion(PropValueUnion) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
PropValueUnion._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ProtectMode - Class in org.apache.hadoop.hive.metastore
 
ProtectMode() - Constructor for class org.apache.hadoop.hive.metastore.ProtectMode
 
ProxyFileSystem - Class in org.apache.hadoop.fs
A FileSystem that can serve a given scheme/authority using some other file system.
ProxyFileSystem() - Constructor for class org.apache.hadoop.fs.ProxyFileSystem
 
ProxyFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.ProxyFileSystem
 
ProxyFileSystem(FileSystem, URI) - Constructor for class org.apache.hadoop.fs.ProxyFileSystem
Create a proxy file system for fs.
ProxyLocalFileSystem - Class in org.apache.hadoop.fs
A Proxy for LocalFileSystem Serves uri's corresponding to 'pfile:///' namespace with using a LocalFileSystem
ProxyLocalFileSystem() - Constructor for class org.apache.hadoop.fs.ProxyLocalFileSystem
 
ProxyLocalFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.ProxyLocalFileSystem
 
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
 
prtner - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
prune() - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
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(Table, ExprNodeDesc, HiveConf, String, Map<String, PrunedPartitionList>) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Get the partition list for the table 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>, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
pruneGroupingSetId() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
prunePartitionNames(List<String>, List<PrimitiveTypeInfo>, 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.
prunePartitionSingleSource(String, DynamicPartitionPruner.SourceInfo) - Method in class org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner
 
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.
pruningOpsRemovedByPriorOpt - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
PTFDesc - Class in org.apache.hadoop.hive.ql.plan
 
PTFDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PTFDesc
 
ptfDesc - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
PTFDeserializer - Class in org.apache.hadoop.hive.ql.plan
 
PTFDeserializer(PTFDesc, StructObjectInspector, Configuration) - 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(Configuration, SerDe, StructObjectInspector, StructObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.exec.PTFPartition
 
PTFPartition(Configuration, SerDe, StructObjectInspector, StructObjectInspector, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.PTFPartition
 
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
 
PTFRollingPartition - Class in org.apache.hadoop.hive.ql.exec
 
PTFRollingPartition(Configuration, SerDe, StructObjectInspector, StructObjectInspector, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
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
 
PTFTopNHash - Class in org.apache.hadoop.hive.ql.exec
 
PTFTopNHash() - Constructor for class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
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
 
PUBLIC - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
publishStat(String, Map<String, String>) - Method in class org.apache.hadoop.hive.hbase.HBaseStatsPublisher
Writes temporary statistics into HBase;
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.
purgeData - Variable in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
purgeData(boolean) - Method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
PushdownTuple - Class in org.apache.hadoop.hive.accumulo.predicate
For use in IteratorSetting construction.
PushdownTuple(IndexSearchCondition, PrimitiveComparison, CompareOp) - Constructor for class org.apache.hadoop.hive.accumulo.predicate.PushdownTuple
 
pushedPredicate - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Portion of predicate to be evaluated by storage handler.
pushedPredicateObject - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Serialized format for filter
pushFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
pushFilters(JobConf, TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pushMsg(String, RecognizerSharedState) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
pushNode(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
pushProjectionsAndFilters(JobConf, Class, String, String) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pushProjectionsAndFilters(JobConf, Class, String, String, boolean) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pushProjectionsAndFilters(JobConf, Path) - Method in class org.apache.hadoop.hive.ql.io.parquet.ProjectionPusher
 
pushRecord() - Method in class org.apache.hadoop.hive.ql.exec.tez.MapRecordSource
 
pushRecord() - Method in interface org.apache.hadoop.hive.ql.exec.tez.RecordSource
 
pushRecord() - Method in class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource
 
pushRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row and push down it to operator tree.
pushRow(InspectableObject) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
put(String, Object) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
Add a key/metric and its value to track
put(String, Object) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
put(BytesBytesMultiHashMap.KvSource, int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
put(MapJoinKey, MapJoinRowContainer) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
put(Writable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
put(Writable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
put(MapJoinKey, MapJoinRowContainer) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinPersistableTableContainer
 
put(Writable, Writable) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerDirectAccess
 
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(Object, Object, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Add a key-value pair to the map.
put(Object, Object, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
put(String, Object) - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Add a non-null value to the map.
putAll(BloomFilter.BitSet) - Method in class org.apache.hive.common.util.BloomFilter.BitSet
Combines the two BitArrays using bitwise OR.
putBuffer(ByteBuffer) - Method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils.ByteBufferAllocatorPool
 
putBuffer(ByteBuffer) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.ByteBufferPoolShim
Release a buffer back to the pool.
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
 
putMetaData(String, String) - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
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
 
putRow(MapJoinObjectSerDeContext, Writable, MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
putRow(MapJoinObjectSerDeContext, Writable, MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
putRow(MapJoinObjectSerDeContext, Writable, MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
putRow(MapJoinObjectSerDeContext, Writable, MapJoinObjectSerDeContext, Writable) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
Adds row from input to the table.
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
putRow(byte[], byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
putRow(long, byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashMap
 
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashMultiSet
 
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashSet
 
putRow(MapJoinObjectSerDeContext, Writable, MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
putRow(BytesWritable, BytesWritable) - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTable
 
putRow(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
putRowInternal(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
putTableLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putToAttributes(String, Map<String, Map<String, PropValueUnion>>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
putToConfiguration(String, String) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
putToConfiguration(String, String) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
putToConfOverlay(String, String) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
putToGroupPrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putToMStringString(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
putToMy_enum_string_map(MyEnum, String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToMy_enum_stringlist_map(MyEnum, List<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToMy_enum_struct_map(MyEnum, MiniStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToMy_enum_structlist_map(MyEnum, List<MiniStruct>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToMy_string_enum_map(String, MyEnum) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToMy_string_string_map(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
putToNameToTypePtr(String, int) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
putToNameToTypePtr(String, int) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
putToOperatorAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
putToOperatorCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
putToParameters(String, String) - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Insert an individual parameter to a Partition's parameter-set.
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
putToPart_vals(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
putToPart_vals(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
putToPartitionSpecs(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
putToPartStats(String, List<ColumnStatisticsObj>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
putToProperties(String, String) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
putToProperties(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
putToQualifiers(String, TTypeQualifierValue) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
putToQueryAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
putToQueryCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
putToRolePrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putToSkewedColValueLocationMaps(List<String>, String) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
putToStageAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
putToStageCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
putToSuccess(String, Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
putToSuccess(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
putToTaskAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
putToTaskCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
putToUserPrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putUserLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putWithCheck(String, String, String, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Adds column to RR, checking for duplicate columns.
PutWritable - Class in org.apache.hadoop.hive.hbase
 
PutWritable() - Constructor for class org.apache.hadoop.hive.hbase.PutWritable
 
PutWritable(Put) - Constructor for class org.apache.hadoop.hive.hbase.PutWritable
 
pvalMatches(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Returns true if partial has the same values as full for all values that aren't empty in partial.
PYTHON_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 

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
 
QBParseInfo.ClauseType - Enum in org.apache.hadoop.hive.ql.parse
 
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
 
QFileClient - Class in org.apache.hive.beeline.util
QTestClient.
QFileClient(HiveConf, String, String, String, String) - Constructor for class org.apache.hive.beeline.util.QFileClient
 
QTestGenTask - Class in org.apache.hadoop.hive.ant
 
QTestGenTask() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask
 
QTestGenTask.DisabledQFileFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.DisabledQFileFilter(Set<String>) - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.DisabledQFileFilter
 
QTestGenTask.IncludeFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.IncludeFilter(Set<String>) - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.IncludeFilter
 
QTestGenTask.QFileFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.QFileFilter(Set<String>) - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
QTestGenTask.QFileRegexFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.QFileRegexFilter(String) - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.QFileRegexFilter
 
qualifierName - Variable in class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
The column qualifier name
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.
quantiles - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
Query - Class in org.apache.hadoop.hive.ql.plan.api
 
Query() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
 
Query(String, String, Map<String, String>, Map<String, Long>, Graph, List<Stage>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
 
Query(Query) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
Performs a deep copy on other.
Query._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
QueryFailedException - Exception in org.apache.hive.hcatalog.streaming
 
QueryFailedException(String, CommandNeedRetryException) - Constructor for exception org.apache.hive.hcatalog.streaming.QueryFailedException
 
queryfound - Variable in class org.apache.hadoop.hive.common.io.FetchConverter
 
queryPlan - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
QueryPlan - Class in org.apache.hadoop.hive.ql.plan.api
 
QueryPlan() - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
QueryPlan(List<Query>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
QueryPlan(QueryPlan) - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Performs a deep copy on other.
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, String, String) - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlan._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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 - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
QueryProperties - Class in org.apache.hadoop.hive.ql
QueryProperties.
QueryProperties() - Constructor for class org.apache.hadoop.hive.ql.QueryProperties
 
queryStatementExpression(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
queryStatementExpressionBody(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
QUESTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
QUESTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
QUESTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
QUESTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
QUESTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
queued - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
QueueException - Exception in org.apache.hive.hcatalog.templeton
Unable to queue the job
QueueException(String) - Constructor for exception org.apache.hive.hcatalog.templeton.QueueException
 
QueueStatusBean - Class in org.apache.hive.hcatalog.templeton
QueueStatusBean - The results of an exec call.
QueueStatusBean(String, String) - Constructor for class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
QueueStatusBean(JobState, JobStatus, JobProfile) - Constructor for class org.apache.hive.hcatalog.templeton.QueueStatusBean
Create a new QueueStatusBean
quit(String) - Method in class org.apache.hive.beeline.Commands
 
QUOTE - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
QUOTE - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
quote - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The quote character when supporting quotes with ability to not split across quoted entries.
QUOTE_CHAR - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
QUOTECHAR - Static variable in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
quoteComments(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
QuotedIdentifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
QuotedIdentifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
QuotedIdentifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
QuotedIdentifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
QuotedIdentifier - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
quoteForWindows(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 

R

randGen - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
random - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
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
 
RAW_DATA_SIZE - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
The name of the statistic Raw Data Size to be published or gathered.
RAWDATASIZE - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
rawInputOI - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
RawStore - Interface in org.apache.hadoop.hive.metastore
 
RawStore.CanNotRetry - Annotation Type in org.apache.hadoop.hive.metastore
Annotation to skip retries
RawStoreProxy - Class in org.apache.hadoop.hive.metastore
 
RawStoreProxy(HiveConf, Configuration, Class<? extends RawStore>, int) - Constructor for class org.apache.hadoop.hive.metastore.RawStoreProxy
 
RBRACE - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
RBRACE - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
RBRACKET - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
RBRACKET - Static variable in class org.apache.hadoop.hive.serde2.SerDeUtils
 
RCFILE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
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
 
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
 
RCFileCat - Class in org.apache.hadoop.hive.cli
 
RCFileCat() - Constructor for class org.apache.hadoop.hive.cli.RCFileCat
 
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
 
RCFileMapReduceInputFormat<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hive.hcatalog.rcfile
 
RCFileMapReduceInputFormat() - Constructor for class org.apache.hive.hcatalog.rcfile.RCFileMapReduceInputFormat
 
RCFileMapReduceOutputFormat - Class in org.apache.hive.hcatalog.rcfile
The RC file input format using new Hadoop mapreduce APIs.
RCFileMapReduceOutputFormat() - Constructor for class org.apache.hive.hcatalog.rcfile.RCFileMapReduceOutputFormat
 
RCFileMapReduceRecordReader<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hive.hcatalog.rcfile
 
RCFileMapReduceRecordReader() - Constructor for class org.apache.hive.hcatalog.rcfile.RCFileMapReduceRecordReader
 
RCFileMergeDesc - Class in org.apache.hadoop.hive.ql.plan
Descriptor for Fast file merge RC file operator.
RCFileMergeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RCFileMergeDesc
 
RCFileMergeDesc(DynamicPartitionCtx, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.RCFileMergeDesc
 
RCFileMergeOperator - Class in org.apache.hadoop.hive.ql.exec
Fast file merge operator for RC files.
RCFileMergeOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.RCFileMergeOperator
 
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
 
RCFileStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
RCFileStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileStorageFormatDescriptor
 
RCFileValueBufferWrapper - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileValueBufferWrapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
rdatetime - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
re - Variable in class org.apache.hive.hcatalog.data.transfer.HCatReader
 
read() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
read(byte[], int, int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
read() - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
read(byte[]) - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
read() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads a typed bytes sequence and converts it to a Java object.
read() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
read() - Method in class org.apache.hadoop.hive.hbase.DataInputInputStream
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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, MapJoinObjectSerDeContext, Writable) - 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(ObjectInspector, Object) - 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(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
read() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
read(boolean) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Read one byte from the byte buffer.
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
read(byte[], int, int) - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
read() - Method in class org.apache.hive.hcatalog.data.transfer.HCatReader
This should be called at slave nodes to read HCatRecords
read() - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatInputFormatReader
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRow
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
read(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
READ_ALL_COLUMNS - Static variable in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
READ_COLUMN_IDS_CONF_STR - Static variable in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
READ_COLUMN_NAMES_CONF_STR - Static variable in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
readAll(byte[], int, int) - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
readArray(ArrayWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readArray() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readBeyondBufferRangeWarned() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readBeyondBufferRangeWarned() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readBeyondBufferRangeWarned() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readBeyondBufferRangeWarned() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readBeyondConfiguredFieldsWarned() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readBeyondConfiguredFieldsWarned() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readBeyondConfiguredFieldsWarned() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readBeyondConfiguredFieldsWarned() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readBinary(DeserializeRead.ReadBinaryResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readBinary(DeserializeRead.ReadBinaryResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readBinary(DeserializeRead.ReadBinaryResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readBinary(DeserializeRead.ReadBinaryResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readBinary() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readBinary() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readBool() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the boolean following a Type.BOOL code.
readBool(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readBool() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readBool() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readBoolean(BooleanWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readBoolean() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readBoolean() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readBoolean() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readBoolean() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readBoolean() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readBuffer(int, boolean) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.ZeroCopyReaderShim
Get a ByteBuffer from the FSDataInputStream - this can be either a HeapByteBuffer or an MappedByteBuffer.
readByte() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the byte following a Type.BYTE code.
readByte(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readByte(ByteWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readByte() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readByte() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readByte() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readByte() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readByte() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readByte() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readByte() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readByteBuffer(FSDataInputStream, ByteBuffer) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
readByteBuffer(FSDataInputStream, ByteBuffer) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
readByteBuffer(FSDataInputStream, ByteBuffer) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Reads data into ByteBuffer.
readBytes() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the bytes following a Type.BYTES code.
readBytes(BytesWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readBytes() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readChar() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readChar() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
 
readChar() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
readCheckNull() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readCheckNull() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readCheckNull() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readCheckNull() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readColumn(DataInput, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
readDate(DeserializeRead.ReadDateResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readDate(DeserializeRead.ReadDateResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readDate(DeserializeRead.ReadDateResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readDate(DeserializeRead.ReadDateResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readDatum(DataInput) - Static method in class org.apache.hive.hcatalog.data.ReaderWriter
 
readDirect(FSDataInputStream, int, ByteBuffer) - Static method in class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils
 
readDouble() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the double following a Type.DOUBLE code.
readDouble(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readDouble(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readDouble() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readDouble() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readDouble() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readDouble() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readDouble() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readDouble() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readDouble() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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.
ReadEntity - Class in org.apache.hive.hcatalog.data.transfer
 
ReadEntity.Builder - Class in org.apache.hive.hcatalog.data.transfer
This class should be used to build ReadEntity.
ReadEntity.Builder() - Constructor for class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
reader - Variable in class org.apache.hadoop.hive.cli.CliDriver
 
Reader - Interface in org.apache.hadoop.hive.ql.io.orc
The interface for reading ORC files.
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BooleanTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ByteTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DateTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.IntTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.LongTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ShortTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDictionaryTreeReader
 
reader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringTreeReader
 
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
 
ReaderContext - Interface in org.apache.hive.hcatalog.data.transfer
This read context is obtained by the master node and should be distributed to the slaves.
ReaderImpl - Class in org.apache.hadoop.hive.ql.io.orc
 
ReaderImpl(Path, OrcFile.ReaderOptions) - Constructor for class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
Constructor that let's the user specify additional options.
readerOptions(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
 
ReaderWriter - Class in org.apache.hive.hcatalog.data
 
ReaderWriter() - Constructor for class org.apache.hive.hcatalog.data.ReaderWriter
 
readFieldBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readFieldBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readFieldEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readFieldEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.hbase.PutWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.hbase.ResultWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomVertexConfiguration
 
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.OrcFileKeyWrapper
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
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.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
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
readFields(byte[], int, int, Schema, Schema) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
readFields(byte[], Schema, Schema) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Always reuse the bytes array if length of bytes array is equal or greater to the current record, otherwise create a new one.
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.shims.CombineHiveKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
 
readFields(DataInput) - Method in class org.apache.hive.hcatalog.templeton.tool.NullSplit
 
readFloat() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the float following a Type.FLOAT code.
readFloat(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readFloat(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readFloat() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readFloat() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readFloat() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readFloat() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readFloat() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readFromList(List<LongWritable>) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readFromRow(ByteStream.Output, MapJoinKey, Object[], List<ObjectInspector>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
readFromRow(Object[], List<ObjectInspector>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
readFromString(String) - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
readFromString(String) - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Populate this validTxnList from the string.
readFromString(String) - Method in class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
readFromVector(ByteStream.Output, MapJoinKey, Object[], List<ObjectInspector>, 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.
readHiveChar(DeserializeRead.ReadHiveCharResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readHiveChar(DeserializeRead.ReadHiveCharResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readHiveChar(DeserializeRead.ReadHiveCharResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readHiveChar(DeserializeRead.ReadHiveCharResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readHiveDecimal(DeserializeRead.ReadDecimalResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readHiveDecimal(DeserializeRead.ReadDecimalResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readHiveDecimal(DeserializeRead.ReadDecimalResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readHiveDecimal(DeserializeRead.ReadDecimalResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readHiveVarchar(DeserializeRead.ReadHiveVarcharResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readHiveVarchar(DeserializeRead.ReadHiveVarcharResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readHiveVarchar(DeserializeRead.ReadHiveVarcharResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readHiveVarchar(DeserializeRead.ReadHiveVarcharResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readI16() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readI16() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readI32() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readI32() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readI64() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readI64() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readInt() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the integer following a Type.INT code.
readInt(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readInt(IntWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readInt() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readInt() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readInt() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readInt() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readInt() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readInt(long) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readIntervalDayTime(DeserializeRead.ReadIntervalDayTimeResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readIntervalDayTime(DeserializeRead.ReadIntervalDayTimeResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readIntervalDayTime(DeserializeRead.ReadIntervalDayTimeResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readIntervalDayTime(DeserializeRead.ReadIntervalDayTimeResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readIntervalYearMonth(DeserializeRead.ReadIntervalYearMonthResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readIntervalYearMonth(DeserializeRead.ReadIntervalYearMonthResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readIntervalYearMonth(DeserializeRead.ReadIntervalYearMonthResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readIntervalYearMonth(DeserializeRead.ReadIntervalYearMonthResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readIsNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
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
readList() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the list following a Type.LIST code.
readListBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
This method always return the same instance of TList to avoid creating new instances.
readListBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readListEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readListEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readLong() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the long following a Type.LONG code.
readLong(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readLong(LongWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readLong() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readLong() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readLong() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readLong() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readLong() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readMap() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the map following a Type.MAP code.
readMap(MapWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readMap() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readMapBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
This method always return the same instance of TMap to avoid creating new instances.
readMapBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readMapEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readMapEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readMapHeader() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the header following a Type.MAP code.
readMessageBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readMessageBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readMessageEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readMessageEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readMetaData(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
readMethod - Variable in class org.apache.hive.spark.client.metrics.InputMetrics
 
readNByteLong(long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readNByteLong(long, int, WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readNext() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
readObject() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readOnly - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
readOperationLog(boolean, long) - Method in class org.apache.hadoop.hive.ql.session.OperationLog
Read operation execution logs from log file
readOrcByteArrays(InStream, IntegerReader, LongColumnVector, BytesColumnVector, long) - Static method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BytesColumnVectorUtil
 
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.
readRaw() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads a typed bytes sequence.
readRawBool() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BOOL code.
readRawByte() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw byte following a Type.BYTE code.
readRawBytes() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BYTES code.
readRawDouble() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.DOUBLE code.
readRawFloat() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.FLOAT code.
readRawInt() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.INT code.
readRawLong() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.LONG code.
readRawString() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.STRING code.
readRowIndex(StripeInformation, OrcProto.StripeFooter, boolean[], OrcProto.RowIndex[], boolean[], OrcProto.BloomFilterIndex[]) - Method in class org.apache.hadoop.hive.ql.io.orc.MetadataReader
 
readSetBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
This method always return the same instance of TSet to avoid creating new instances.
readSetBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readSetEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readSetEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readShort() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the short following a Type.SHORT code.
readShort(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readShort() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readShort() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readShort() - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readShort() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readShort() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readSortedMap() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readString() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the string following a Type.STRING code.
readString(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
readString(DeserializeRead.ReadStringResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readString(DeserializeRead.ReadStringResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readString(DeserializeRead.ReadStringResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readString(DeserializeRead.ReadStringResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readString() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readString() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readStripeFooter(StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.MetadataReader
 
readStructBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readStructBegin() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readStructEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readStructEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readText(Text) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readText() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readTimestamp(DeserializeRead.ReadTimestampResults) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
readTimestamp(DeserializeRead.ReadTimestampResults) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
readTimestamp(DeserializeRead.ReadTimestampResults) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
readTimestamp(DeserializeRead.ReadTimestampResults) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
readType() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads a type byte and returns the corresponding Type.
readType() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readTypeCode() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
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.
readVector() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the vector following a Type.VECTOR code.
readVectorHeader() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Reads the header following a Type.VECTOR code.
readVInt(VIntWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readVInt() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readVInt(byte[], int, LazyBinaryUtils.VInt) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Reads a zero-compressed encoded int from a byte array and returns it.
readVInt() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readVInt(WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readVLong(VLongWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readVLong() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readVLong(byte[], int, LazyBinaryUtils.VLong) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Reads a zero-compressed encoded long from a byte array and returns it.
readVLong() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readVLong(WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
readVLongFromByteArray(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Read a zero-compressed encoded long from a byte array.
readWritable(Writable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
readWritable() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
ready() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
READY_FOR_CLEANING - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
realAuthority - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 
realFile(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Shamelessly cloned from GenericOptionsParser.
realOutputFormat - Variable in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
realScheme - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 
realUgi - Variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
realUri - Variable in class org.apache.hadoop.fs.ProxyFileSystem
 
receiveFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
receiveFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
recommendInputName(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Recommend name for the expression
reconnect() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
reconnect() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Tries to reconnect this MetaStoreClient to the MetaStore.
reconnect(String) - Method in class org.apache.hive.beeline.Commands
 
reconstructQueryDef(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
Initialize the visitor to use the QueryDefDeserializer Use the order defined in QueryDefWalker to visit the QueryDef
record(String) - Method in class org.apache.hive.beeline.Commands
Save or stop saving all output to a file.
RECORD_INTERVAL_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
recordIdColumn(int) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Which column the row id field is in.
RecordIdentifier - Class in org.apache.hadoop.hive.ql.io
Gives the Record identifier 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
 
RecordIdentifier.Field - Enum in org.apache.hadoop.hive.ql.io
This is in support of VirtualColumn.ROWID Contains metadata about each field in RecordIdentifier that needs to be part of ROWID which is represented as a struct RecordIdentifier.StructInfo.
RecordIdentifier.StructInfo - Class in org.apache.hadoop.hive.ql.io
RecordIdentifier is passed along the operator tree as a struct.
RecordIdentifier.StructInfo() - Constructor for class org.apache.hadoop.hive.ql.io.RecordIdentifier.StructInfo
 
recordLength - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
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(JobConf, ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
RecordReader - Interface in org.apache.hadoop.hive.ql.exec
RecordReader.
recordReader - Variable in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
RecordReader - Interface in org.apache.hadoop.hive.ql.io.orc
A row-by-row iterator for ORC files.
recordReader() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RecordReaderFactory - Class in org.apache.hadoop.hive.ql.io.orc
Factory to create ORC tree readers.
RecordReaderFactory() - Constructor for class org.apache.hadoop.hive.ql.io.orc.RecordReaderFactory
 
RecordReaderUtils - Class in org.apache.hadoop.hive.ql.io.orc
Stateless methods shared between RecordReaderImpl and EncodedReaderImpl.
RecordReaderUtils() - Constructor for class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils
 
RecordReaderUtils.ByteBufferAllocatorPool - Class in org.apache.hadoop.hive.ql.io.orc
 
RecordReaderUtils.ByteBufferAllocatorPool() - Constructor for class org.apache.hadoop.hive.ql.io.orc.RecordReaderUtils.ByteBufferAllocatorPool
 
RecordSource - Interface in org.apache.hadoop.hive.ql.exec.tez
 
RecordUpdater - Interface in org.apache.hadoop.hive.ql.io
API for supporting updating records.
recordValue - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
RecordWriter.
recordWriter() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RecordWriter - Interface in org.apache.hive.hcatalog.streaming
 
recoverFromMismatchedSet(IntStream, RecognitionException, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
recoverFromMismatchedSet(IntStream, RecognitionException, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
recoverFromMismatchedSet(IntStream, RecognitionException, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
recoverFromMismatchedSet(IntStream, RecognitionException, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
recursiveDelete(File) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
recursiveDelete just recursively deletes a dir - you'd think Java would have something to do this??
recv_abort_txn() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_dynamic_partitions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partition_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partitions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partitions_pspec() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partitions_req() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_function() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_partition_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_partitions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_table_with_cascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_table_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_append_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_append_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_append_partition_by_name_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_append_partition_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_cancel_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_CancelDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_CancelOperation() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_check_lock() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_clean() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_CloseOperation() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_CloseSession() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_commit_txn() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_compact() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_function() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_table_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_delete_partition_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_delete_table_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_function() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_index_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition_by_name_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partitions_req() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_table_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_exchange_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_execute() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_ExecuteStatement() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_fetchAll() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_fetchN() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_fetchOne() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_FetchResults() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_fire_listener_event() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_aggr_stats_for() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_all_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_config_value() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_current_notificationEventId() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_fields() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_fields_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_function() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_functions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_index_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_index_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_next_notification() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_open_txns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_open_txns_info() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_part_specs_by_filter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_names_ps() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_by_expr() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_by_filter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_by_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_ps() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_ps_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_pspec() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_statistics_req() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_principals_in_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_privilege_set() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_role_grants_for_principal() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_schema() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_schema_with_environment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_table_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_table_names_by_filter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_table_objects_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_table_statistics_req() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_type_all() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_GetCatalogs() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_GetColumns() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_GetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_GetFunctions() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_GetInfo() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_getMetaConf() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_GetOperationStatus() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_getQueryPlan() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_GetResultSetMetadata() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_GetSchemas() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_GetTables() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_GetTableTypes() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_GetTypeInfo() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_grant_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_grant_revoke_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_grant_revoke_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_grant_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_heartbeat() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_heartbeat_txn_range() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_isPartitionMarkedForEvent() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_list_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_list_roles() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_lock() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_markPartitionForEvent() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_open_txns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_OpenSession() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_partition_name_has_valid_characters() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_partition_name_to_spec() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_partition_name_to_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_rename_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_renew_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_RenewDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
recv_revoke_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_revoke_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_set_aggr_stats_for() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_set_ugi() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_setMetaConf() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_show_compact() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_show_locks() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_unlock() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_update_partition_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_update_table_column_statistics() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
redactLogString(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.hooks.HookUtils
 
Redactor - Class in org.apache.hadoop.hive.ql.hooks
 
Redactor() - Constructor for class org.apache.hadoop.hive.ql.hooks.Redactor
 
redactQuery(String) - Method in class org.apache.hadoop.hive.ql.hooks.Redactor
Implementations may modify the query so that when placed in the job.xml and thus potenially exposed to admin users, the query does not expose sensitive information.
reduce(InputStream, OutputStream, Reducer) - Method in class org.apache.hadoop.hive.contrib.mr.GenericMR
 
reduce(Reader, Writer, Reducer) - Method in class org.apache.hadoop.hive.contrib.mr.GenericMR
 
reduce(String, Iterator<String[]>, Output) - Method in interface org.apache.hadoop.hive.contrib.mr.Reducer
Reduce.
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
 
REDUCENAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
reduceProgress - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
Reducer - Interface in org.apache.hadoop.hive.contrib.mr
Simple reducer interface.
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(JobConf, ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordProcessor
 
ReduceRecordSource - 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.
ReduceRecordSource() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource
 
reducerHash - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
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
 
ReduceSinkDeDuplication.ReduceSinkDeduplicateProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.correlation
 
ReduceSinkDeDuplication.ReduceSinkDeduplicateProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.ReduceSinkDeduplicateProcCtx
 
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, AcidUtils.Operation) - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
ReduceSinkDesc.ReducerTraits - Enum in org.apache.hadoop.hive.ql.plan
 
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
 
ReduceSinkOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counters.
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(ProcessorContext) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ReduceTezProcessor
 
ReduceTran - Class in org.apache.hadoop.hive.ql.exec.spark
 
ReduceTran() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.ReduceTran
 
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
 
referer - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
ReflectionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
ReflectionStructObjectInspector works on struct data that is stored as a native Java object.
ReflectionStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
MyField.
ReflectionStructObjectInspector.MyField() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
ReflectionStructObjectInspector.MyField(int, Field, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
ReflectionUtil - Class in org.apache.hive.common.util
Same as Hadoop ReflectionUtils, but (1) does not leak classloaders (or shouldn't anyway, we rely on Guava cache, and could fix it otherwise); (2) does not have a hidden epic lock.
ReflectionUtil() - Constructor for class org.apache.hive.common.util.ReflectionUtil
 
ReflectiveCommandHandler - Class in org.apache.hive.beeline
A Command implementation that uses reflection to determine the method to dispatch the command.
ReflectiveCommandHandler(BeeLine, String[], Completer[]) - Constructor for class org.apache.hive.beeline.ReflectiveCommandHandler
 
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
 
refreshDefaultQueue(Configuration, String) - Method in class org.apache.hadoop.hive.schshim.FairSchedulerShim
 
refreshDefaultQueue(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
refreshDefaultQueue(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
Load the fair scheduler queue for given user if available.
refreshDefaultQueue(Configuration, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Reset the default fair scheduler queue mapping to end user.
refreshDefaultQueue(Configuration, String) - Method in interface org.apache.hadoop.hive.shims.SchedulerShim
Reset the default fair scheduler queue mapping to end user.
refreshLocalResourcesFromConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
refreshMemoryUsed() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Get the current memory usage by recalculating it.
refreshRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
RegexSerDe - Class in org.apache.hadoop.hive.contrib.serde2
RegexSerDe uses regular expression (regex) to serialize/deserialize.
RegexSerDe() - Constructor for class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
RegexSerDe - Class in org.apache.hadoop.hive.serde2
RegexSerDe uses regular expression (regex) to deserialize data.
RegexSerDe() - Constructor for class org.apache.hadoop.hive.serde2.RegexSerDe
 
register(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
register(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan
 
register(TaskAttemptContext, TaskCommitContextRegistry.TaskCommitterProxy) - Method in class org.apache.hive.hcatalog.mapreduce.TaskCommitContextRegistry
Method to register call-backs to control commits and aborts of TaskAttempts.
register(ServiceStateChangeListener) - Method in class org.apache.hive.service.AbstractService
 
register(ServiceStateChangeListener) - Method in class org.apache.hive.service.FilterService
 
register(ServiceStateChangeListener) - Method in interface org.apache.hive.service.Service
Register an instance of the service state change events.
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcProto
 
registerClient(String, String, RpcDispatcher) - Method in class org.apache.hive.spark.client.rpc.RpcServer
Tells the RPC server to expect a connection from a new client.
registerFunction(String, Class<?>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Registers the appropriate kind of temporary function based on a class's type.
registerGenericUDAF(String, GenericUDAFResolver, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerGenericUDF(String, Class<? extends GenericUDF>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerGenericUDTF(String, Class<? extends GenericUDTF>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerIfNot(long) - Static method in class org.apache.hadoop.hive.metastore.Deadline
register a Deadline threadlocal object to current thread.
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.
registerJob(String, String, String, Map<String, Object>) - Method in class org.apache.hive.hcatalog.templeton.LauncherDelegator
 
registerMacro(String, ExprNodeDesc, List<String>, List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerMacro(String, ExprNodeDesc, List<String>, List<TypeInfo>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerOutParameter(int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutParameter(int, int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutParameter(int, int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
registerOutputFormatSubstitute(Class<?>, Class<? extends HiveOutputFormat>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register a substitute.
registerPermanentFunction(String, String, boolean, FunctionInfo.FunctionResource[]) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerPermanentFunction(String, String, boolean, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerTableFunction(String, Class<? extends TableFunctionResolver>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerTemporaryMacro(String, ExprNodeDesc, List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Registers the appropriate kind of temporary function based on a class's type.
registerTemporaryUDF(String, Class<?>, FunctionInfo.FunctionResource...) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Registers the appropriate kind of temporary function based on a class's type.
registerUDAF(String, Class<? extends UDAF>, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerUDF(String, Class<? extends UDF>, boolean, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
registerUDF(String, Class<? extends UDF>, boolean, String, FunctionInfo.FunctionResource...) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
Registry - Class in org.apache.hadoop.hive.ql.exec
 
Registry() - Constructor for class org.apache.hadoop.hive.ql.exec.Registry
 
Registry - Static variable in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
RegistryV2 - Static variable in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
regularBody(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rehash(String) - Method in class org.apache.hive.beeline.Commands
 
ReInit(Reader, int, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(Reader, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(Reader) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream, String, int, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream, int, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream, String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream, String, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream, int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
ReInit(InputStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Reinitialise.
ReInit(Reader) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Reinitialise.
ReInit(thrift_grammarTokenManager) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Reinitialise.
ReInit(SimpleCharStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Reinitialise parser.
ReInit(SimpleCharStream, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Reinitialise parser.
rejected(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
relative(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
relativeToAbsolutePath(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
release(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
release(String) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
 
release(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
release(boolean) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
1.
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
 
releaseBuffer(ByteBuffer) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.ZeroCopyReaderShim
Release a ByteBuffer obtained from a read on the Also move the in stream by that amount.
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, long) - 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
 
releaseSavepoint(Savepoint) - Method in class org.apache.hive.jdbc.HiveConnection
 
reloadAuxJars() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
ReloadFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
 
ReloadFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ReloadFunctionDesc
 
reloadFunctions() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
reloadFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
reloadHashTable(byte, int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
Reload hashtable from the hash partition.
reloadHashTable(byte, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
reloadKeys() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
ReloadProcessor - Class in org.apache.hadoop.hive.ql.processors
used for reload auxiliary and jars without restarting hive server2
ReloadProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.ReloadProcessor
 
RelOptHiveTable - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
RelOptHiveTable(RelOptSchema, String, RelDataType, Table, List<ColumnInfo>, List<ColumnInfo>, List<VirtualColumn>, HiveConf, Map<String, PrunedPartitionList>, AtomicInteger) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
remainder(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
remainderUnsignedLong(long, long) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
If we can assume JDK 1.8, this should use java.lang.Long.remainderUnsigned(), which will be replaced with intrinsics in JVM.
remainingTransactions() - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Remaining transactions are the ones that are not committed or aborted or open.
remoteBlocksFetched - Variable in class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
Number of remote blocks fetched in shuffles by tasks.
remoteBytesRead - Variable in class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
Total number of remote bytes read from the shuffle by tasks.
RemoteDriver - Class in org.apache.hive.spark.client
Driver code for the Spark client library.
RemoteHiveSparkClient - Class in org.apache.hadoop.hive.ql.exec.spark
RemoteSparkClient is a wrapper of SparkClient, which wrap a spark job request and send to an remote SparkContext.
RemoteSparkJobMonitor - Class in org.apache.hadoop.hive.ql.exec.spark.status
RemoteSparkJobMonitor monitor a RSC remote job status in a loop until job finished/failed/killed.
RemoteSparkJobMonitor(HiveConf, RemoteSparkJobStatus) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.RemoteSparkJobMonitor
 
RemoteSparkJobRef - Class in org.apache.hadoop.hive.ql.exec.spark.status.impl
 
RemoteSparkJobRef(HiveConf, JobHandle<Serializable>, RemoteSparkJobStatus) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobRef
 
RemoteSparkJobStatus - Class in org.apache.hadoop.hive.ql.exec.spark.status.impl
Used with remove spark client.
RemoteSparkJobStatus(SparkClient, JobHandle<Serializable>, long) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus
 
remove(HiveInterruptCallback) - Static method in class org.apache.hadoop.hive.common.HiveInterruptUtils
 
remove() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
remove() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
remove() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
remove() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
remove(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
remove(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
remove(String) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
Removes the specified key from the object cache.
remove(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
remove() - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
remove() - Method in class org.apache.hadoop.hive.ql.exec.spark.HiveBaseFunctionResultList.ResultIterator
 
remove(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
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.SparkWork
remove removes a node from the graph and removes all edges with work as start or end point.
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.
remove() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingIterator
 
remove(Object, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Remove a key-value pair from the map.
remove(Object, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
remove() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec.HCatPartitionIterator
 
remove() - Method in class org.apache.hive.hcatalog.api.repl.HCatReplicationTaskIterator
 
remove(int) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
remove(int) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
remove(int) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
remove(HCatFieldSchema) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
remove(String) - Method in class org.apache.hive.hcatalog.templeton.JsonBuilder
Remove a value from the map.
removeAfter() - Method in class org.apache.hadoop.hive.common.DiskRangeList
Removes an element after current from the list.
removeAttr(String) - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Op
 
removeBloomFilter(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
removeBranch(AppMasterEventOperator) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
Remove an operator branch.
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
 
removeColStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
removeColumns(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
removeCurrentOperationLog() - Static method in class org.apache.hadoop.hive.ql.session.OperationLog
 
removeDelegationToken(JobId) - Method in class org.apache.hive.hcatalog.templeton.tool.DelegationTokenCache
 
removeDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Remove the dependent task.
RemoveDynamicPruningBySize - Class in org.apache.hadoop.hive.ql.optimizer
If we expect the number of keys for dynamic pruning to be too large we disable it.
RemoveDynamicPruningBySize() - Constructor for class org.apache.hadoop.hive.ql.optimizer.RemoveDynamicPruningBySize
 
removeEntry(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
removeExpiredOperations(OperationHandle[]) - Method in class org.apache.hive.service.cli.operation.OperationManager
 
removeExpiredTokens() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
Remove expired tokens.
removeField(Kryo, Class, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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
 
removeFromUDFLoaders(ClassLoader) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
removeMasterKey(Integer) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
removeMasterKey(Integer) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
removeMasterKey(int) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
removeMasterKey(int) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Remove key for given id.
removeMasterKey(int) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
removeMasterKey(int) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
removeMetadata(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
removeOperator(Operator<?>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
removeOperator(Operator<?>, Operator<?>, Operator<?>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
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.
removeQuery(int) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Removes a query from the execution list.
removeRawStore() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
removeReduceSinkForGroupBy(ReduceSinkOperator, GroupByOperator, ParseContext, AbstractCorrelationProcCtx) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
removeRole(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
removeRole(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
removeScratchDir() - Method in class org.apache.hadoop.hive.ql.Context
Remove any created scratch directories.
removeSelf() - Method in class org.apache.hadoop.hive.common.DiskRangeList
Removes the current element from the list.
removeService(Service) - Method in class org.apache.hive.service.CompositeService
 
removeShutdownHook(Runnable) - Static method in class org.apache.hive.common.util.ShutdownHookManager
Removes a shutdownHook.
removeStatistics(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
removeStreams(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
removeStripes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
removeStripeStats(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
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
 
removeToken(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
removeToken(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
removeToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
removeToken(DelegationTokenIdentifier) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Remove token.
removeToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
removeToken(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
removeTypes(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
removeUnionOperators(Configuration, GenTezProcContext, BaseWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
removeUnionOperators(Configuration, GenSparkProcContext, BaseWork) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
removeValueTag(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
removeVirtualColumns(Collection<String>) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
removeVirtualColumnTypes(List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
removeWalked(ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
removeWalkedAll(Collection<ReduceSinkOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
rename(Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
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.
rename_partition(String, String, List<String>, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.rename_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
rename_partition(String, String, List<String>, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.rename_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
rename_partition(String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
rename_partition(String, String, List<String>, Partition) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
rename_partition(String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
renameDir(Path, Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
renameDir(Path, Path, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
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(String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
renamePartition(String, String, List<String>, Partition) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
rename a partition to a new partition
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, Map<String, String>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
renameTable(String, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Renames a table.
renameTable(String, String, String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
renameTable(String, String, String, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Rename a table.
renameTable(String, String, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Rename an hcat table.
renameWithPerms(FileSystem, Path, Path, boolean, Configuration) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
renderOrigin(StringBuilder, ASTNodeOrigin) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
renew_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
renew_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
renew_delegation_token(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
renewDelegationToken(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Renew a delegation token to extend its lifetime.
renewDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
renewDelegationToken(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
renewDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.DelegationTokenSecretManager
 
renewDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
renewDelegationToken(String) - Method in class org.apache.hive.hcatalog.api.HCatClient
Renew delegation token.
renewDelegationToken(String) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
renewDelegationToken(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
renewDelegationToken(String) - Method in class org.apache.hive.service.auth.HiveAuthFactory
 
renewDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.CLIService
 
renewDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.CLIServiceClient
 
renewDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.EmbeddedCLIServiceClient
 
renewDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in interface org.apache.hive.service.cli.ICLIService
 
renewDelegationToken(HiveAuthFactory, String) - Method in interface org.apache.hive.service.cli.session.HiveSession
 
renewDelegationToken(HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
renewDelegationToken(HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
RenewDelegationToken(TRenewDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.RenewDelegationToken_call>) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
RenewDelegationToken(TRenewDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.RenewDelegationToken_call>) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.AsyncIface
 
RenewDelegationToken(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
RenewDelegationToken(TRenewDelegationTokenReq) - Method in interface org.apache.hive.service.cli.thrift.TCLIService.Iface
 
RenewDelegationToken(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
renewDelegationToken(SessionHandle, HiveAuthFactory, String) - Method in class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
renewToken(Token<DelegationTokenIdentifier>, String) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
reopen() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Closes scope if open, and reopens it
reorderFields(byte[]) - Method in class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
 
Repeated - Interface in org.apache.hadoop.hive.ql.io.parquet.convert
Converters for repeated fields need to know when the parent field starts and ends to correctly build lists from the repeated values.
Repeated.RepeatedConverterParent - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
Repeated.RepeatedConverterParent() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedConverterParent
 
Repeated.RepeatedGroupConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
Stands in for a HiveGroupConverter and accumulates multiple values as an ArrayWritable.
Repeated.RepeatedGroupConverter(GroupType, ConverterParent, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
Repeated.RepeatedPrimitiveConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
Stands in for a PrimitiveConverter and accumulates multiple values as an ArrayWritable.
Repeated.RepeatedPrimitiveConverter(PrimitiveType, ConverterParent, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
REPL_STATE_ID - Static variable in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
 
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.
replaceFiles(Path, Path, Path, Path, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
Replaces files in the partition with new data set specified by srcf.
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.
replaceReduceSinkWithSelectOperator(ReduceSinkOperator, ParseContext, AbstractCorrelationProcCtx) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
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.MergeJoinWork
 
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
 
replaceSelfWith(DiskRangeList) - Method in class org.apache.hadoop.hive.common.DiskRangeList
Replaces this element with another in the list; returns the new element.
replaceTask(Task<? extends Serializable>, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
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
 
replaceTaskWithConditionalTask(Task<? extends Serializable>, ConditionalTask) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
replicationClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ReplicationSpec - Class in org.apache.hadoop.hive.ql.parse
Statements executed to handle replication have some additional information relevant to the replication subsystem - this class captures those bits of information.
ReplicationSpec(ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Constructor to construct spec based on either the ASTNode that corresponds to the replication clause itself, or corresponds to the parent node, and will scan through the children to instantiate itself.
ReplicationSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.ReplicationSpec
Default ctor that is useful for determining default states
ReplicationSpec(boolean, boolean, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
ReplicationSpec(Function<String, String>) - Constructor for class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
ReplicationSpec.KEY - Enum in org.apache.hadoop.hive.ql.parse
 
ReplicationSpec.SCOPE - Enum in org.apache.hadoop.hive.ql.parse
 
ReplicationTask - Class in org.apache.hive.hcatalog.api.repl
ReplicationTask captures the concept of what it'd take to replicate changes from one warehouse to another given a notification event that captures what changed.
ReplicationTask(HCatNotificationEvent) - Constructor for class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
ReplicationTask.Factory - Interface in org.apache.hive.hcatalog.api.repl
 
ReplicationUtils - Class in org.apache.hive.hcatalog.api.repl
 
reporter - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
reporter - Variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
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.
reporter - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
reporter - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
reportProgress() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
repositionCursor() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
NOTE: Use this method only if isUnixTerminal is true.
reprintLine(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
NOTE: Use this method only if isUnixTerminal is true.
reprintLineWithColorAsBold(String, Ansi.Color) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
NOTE: Use this method only if isUnixTerminal is true.
reprintMultiLine(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
NOTE: Use this method only if isUnixTerminal is true.
reProcessBigTable(int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
Iterate over the big table row container and feed process() with leftover rows
reProcessBigTable(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
reProcessBigTable(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
For a vectorized row batch from the rows feed from the super MapJoinOperator.
requester - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
requestFormats() - Method in class org.apache.hive.hcatalog.templeton.Server
Check the supported request formats of this server.
requestid - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
RequestPartsSpec - Class in org.apache.hadoop.hive.metastore.api
 
RequestPartsSpec() - Constructor for class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
RequestPartsSpec(RequestPartsSpec._Fields, Object) - Constructor for class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
RequestPartsSpec(RequestPartsSpec) - Constructor for class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
RequestPartsSpec._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requesturi - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
requireCalStats(Configuration, Partition, Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
requiredness - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
Is this a required, skippable or optional field.
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.merge.MergeFileTask
 
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
 
requiresLayout() - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
reserve(int) - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
reserve(int) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
reserve(int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
reset(byte[], int, int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
reset() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
reset() - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
reset() - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
Resets to state before any processLogLine() calls.
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.PTFRollingPartition
 
reset(ByteBuffer...) - Method in class org.apache.hadoop.hive.ql.exec.tez.DataInputByteBuffer
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Additional reset work for BytesColumnVector (releasing scratch bytes for by value strings).
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(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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 - inits 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(boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
reset() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
reset(boolean) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
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.GenericUDAFDateStatsEvaluator
 
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(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator
 
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
 
reset() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
reset(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Reset the byte buffer to the given byte range.
reset(byte[], int) - Method in class org.apache.hadoop.hive.serde2.ByteStream.Input
 
reset() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
reset() - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
reset() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
reset() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
reset(long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
reset() - Method in class org.apache.hive.common.util.BloomFilter
 
resetAggregations(GenericUDAFEvaluator.AggregationBuffer[]) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
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
 
resetCurrentReadBlockToFirstReadBlock() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
resetFactory(Class<? extends ReplicationTask.Factory>) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Package scoped method used for testing - allows resetting the ReplicationTaskFactory used
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
 
resetProjectionColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
resetReadBlocks() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
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
 
resetSequenceNumber() - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
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
 
resetTimeout(long) - Static method in class org.apache.hadoop.hive.metastore.Deadline
reset the timeout value of this timer.
resetToIndex(int) - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
resetValid(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
enlarge the capacity if necessary, to ensure that it can hold the number of elements specified by newValidCapacity argument.
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
 
resize(Object, int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Resize the list.
resize(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
resizeThreshold - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
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 class org.apache.hadoop.hive.ql.optimizer.physical.NullScanOptimizer
 
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.SparkCrossProductCheck
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SparkMapJoinResolver
 
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
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.spark.SplitSparkWorkResolver
 
resolve(HCatTable, EnumSet<HCatTable.TableAttribute>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Method to "adopt" the specified attributes from rhs into this HCatTable object.
resolveColumn(RowSchema, ExprNodeColumnDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory
Get ColumnInfo from column expression.
resolveConcatenateMerge(HiveConf) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
alter table ...
resolveCustomPath(OutputJobInfo, Map<String, String>, boolean) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatFileUtil
 
resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf, Path, TableDesc, ArrayList<String>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf, Path, TableDesc, ArrayList<String>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
resolveMapJoinTask(ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx, HiveConf) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
resolvePath(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
resolveUnknownSizes(ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx, HiveConf) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
resource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
resourceList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ResourceType - Enum in org.apache.hadoop.hive.metastore.api
 
resourceType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ResourceUri - Class in org.apache.hadoop.hive.metastore.api
 
ResourceUri() - Constructor for class org.apache.hadoop.hive.metastore.api.ResourceUri
 
ResourceUri(ResourceType, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ResourceUri
 
ResourceUri(ResourceUri) - Constructor for class org.apache.hadoop.hive.metastore.api.ResourceUri
Performs a deep copy on other.
ResourceUri._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
restoreOriginalTracker() - Method in class org.apache.hadoop.hive.ql.Context
 
restoreSession(Driver.QueryState) - Method in class org.apache.hadoop.hive.ql.Driver
 
restoreSessionSpecifiedClassLoader(ClassLoader) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
restrictOrCascade() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
result - Variable in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
result - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
result - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
result - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
RESULT_SET_SCHEMA - Static variable in class org.apache.hive.service.cli.operation.GetTableTypesOperation
 
RESULT_SET_SCHEMA - Static variable in class org.apache.hive.service.cli.operation.MetadataOperation
 
resultOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
resultOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
resultOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPower
 
resultSerializationTime - Variable in class org.apache.hive.spark.client.metrics.Metrics
Amount of time spent serializing task results.
resultSize - Variable in class org.apache.hive.spark.client.metrics.Metrics
The number of bytes sent back to the driver by tasks.
ResultVector - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
ResultWritable - Class in org.apache.hadoop.hive.hbase
 
ResultWritable() - Constructor for class org.apache.hadoop.hive.hbase.ResultWritable
 
ResultWritable(Result) - Constructor for class org.apache.hadoop.hive.hbase.ResultWritable
 
ret - Variable in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
retMap - Variable in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
retrieve(InspectableObject) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
retrieve(String, Callable<T>) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
retrieve(String, Callable<T>) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
Retrieve object from cache.
retrieve(String, Callable<T>) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
retrieve(SeedObject) - Method in class org.apache.hadoop.hive.serde2.avro.InstanceCache
Retrieve (or create if it doesn't exist) the correct Instance for this SeedObject
retrieve(SeedObject, Set<SeedObject>) - Method in class org.apache.hadoop.hive.serde2.avro.InstanceCache
Retrieve (or create if it doesn't exist) the correct Instance for this SeedObject using 'seenSchemas' to resolve circular references
retrieveAsync(String, Callable<T>) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
retrieveAsync(String, Callable<T>) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
Retrieve object from cache asynchronously.
retrieveAsync(String, Callable<T>) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
retrievePassword(DelegationTokenIdentifier) - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
retrieveReaderSchema(Object) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSchemaRetriever
Retrieve the reader avro schema from the given source
retrieveWriterSchema(Object) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSchemaRetriever
Retrieve the writer avro schema from the given source
RetryingHMSHandler - Class in org.apache.hadoop.hive.metastore
 
RetryingMetaStoreClient - Class in org.apache.hadoop.hive.metastore
RetryingMetaStoreClient.
RetryingMetaStoreClient(HiveConf, HiveMetaHookLoader, Map<String, Long>, Class<? extends IMetaStoreClient>) - Constructor for class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
RetryingMetaStoreClient(HiveConf, Class<?>[], Object[], Map<String, Long>, Class<? extends IMetaStoreClient>) - Constructor for class org.apache.hadoop.hive.metastore.RetryingMetaStoreClient
 
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.
returnNulls - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For places where the separators are back to back, should we return a null or an empty string since it is ambiguous.
ReturnNullsKey - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Strings used to lookup the various configurable paramaters of this protocol.
returnResults - Variable in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
returnResults(boolean) - Method in class org.apache.hadoop.hive.metastore.PartitionDropOptions
 
returnSession(SparkSession) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager
Return the given sparkSession to pool.
returnSession(SparkSession) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
 
returnSession(TezSessionState) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
returnType - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer.GenericUDAFInfo
 
returnValue - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.StringHelper
 
retValue - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
ReusableGetAdaptorDirectAccess - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
reverseLookup(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
revoke_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
revoke_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
revoke_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
revoke_privileges(PrivilegeBag, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
revoke_privileges(PrivilegeBag, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
revoke_privileges(PrivilegeBag, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
revoke_role(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
revoke_role(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
revoke_role(String, String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
revoke_role(String, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
revoke_role(String, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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
 
RevokeDesc(List<PrivilegeDesc>, List<PrincipalDesc>, PrivilegeObjectDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
revokeFromLocalWorkers(String) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This will take all entries assigned to workers on a host return them to INITIATED state.
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, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
revokePrivileges(PrivilegeBag, boolean) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
revokePrivileges(PrivilegeBag, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokePrivileges() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveV1Authorizer
 
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
revokeRole(Role, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
revokeRole(Role, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
revokeRole(String, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokeRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveV1Authorizer
 
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
revokeTimedoutWorkers(long) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
This call will return all compaction queue entries assigned to a worker but over the timeout back to the initiated state.
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.
RewriteCanApplyProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyProcFactory
 
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.
RewriteParseContextGenerator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.index.RewriteParseContextGenerator
 
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.calcite.translator
 
RexNodeConverter(RelOptCluster, RelDataType, ImmutableMap<String, Integer>, int, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
RexNodeConverter(RelOptCluster, List<RexNodeConverter.InputCtx>, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter
 
RIGHT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
rightOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
rightTrim(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
rightTrim(BytesColumnVector, int, byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
rightTrimAndTruncate(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
rightTrimAndTruncate(BytesColumnVector, int, byte[], int, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
rightTrimAndTruncateScalar(byte[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
rip - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
rkey - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
Role - Class in org.apache.hadoop.hive.metastore.api
 
Role() - Constructor for class org.apache.hadoop.hive.metastore.api.Role
 
Role(String, int, String) - Constructor for class org.apache.hadoop.hive.metastore.api.Role
 
Role(Role) - Constructor for class org.apache.hadoop.hive.metastore.api.Role
Performs a deep copy on other.
Role._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
RolePrincipalGrant - Class in org.apache.hadoop.hive.metastore.api
 
RolePrincipalGrant() - Constructor for class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
RolePrincipalGrant(String, String, PrincipalType, boolean, int, String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
RolePrincipalGrant(RolePrincipalGrant) - Constructor for class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
Performs a deep copy on other.
RolePrincipalGrant._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
rollback(String) - Method in class org.apache.hive.beeline.Commands
 
rollback() - Method in class org.apache.hive.jdbc.HiveConnection
 
rollback(Savepoint) - Method in class org.apache.hive.jdbc.HiveConnection
 
rollbackCreateTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
rollbackCreateTable(Table) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
rollbackCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after failure adding a new table definition to the metastore during CREATE TABLE.
rollbackDropTable(Table) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
rollbackDropTable(Table) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
rollbackDropTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after failure removing a table definition from the metastore during DROP TABLE.
rollbackTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Rolls back the current transaction if it is active
rollbackTransaction() - Method in interface org.apache.hadoop.hive.metastore.RawStore
Rolls back the current transaction if it is active
rollbackTxn(long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
rollbackTxn(long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Rollback a transaction.
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.
rollMasterKey(AbstractDelegationTokenSecretManager<? extends AbstractDelegationTokenIdentifier>) - Static method in class org.apache.hadoop.security.token.delegation.HiveDelegationTokenSupport
 
rollMasterKeyExt() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
Extension of rollMasterKey to remove expired keys from store.
rootNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
rootOperators - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
rootOps - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
rootTask - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
rootToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
rootToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
rootUnionWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
round(int, HiveDecimal, int, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
round(int, HiveDecimalWritable, int, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
round(int, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
round(int, HiveDecimalWritable, 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
 
ROUND_CEILING - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
ROUND_FLOOR - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
ROUND_HALF_UP - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
ROUND_POWER_TENS_INT128 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5 * 10^(x-1).
ROUND_POWER_TENS_INT31 - Static variable in class org.apache.hadoop.hive.common.type.SqlMathUtil
5 * 10^(x-1).
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, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
routeInputSourceTaskFailedEventToDestination(int, Map<Integer, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
row - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
ROW_COUNT - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
The name of the statistic Row Count to be published or gathered.
row_count - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
ROW_INDEX_STRIDE - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated.
ROW_INDEX_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
ROW_INDEX = 6;
RowBasedSet - Class in org.apache.hive.service.cli
RowBasedSet
RowBasedSet(TableSchema) - Constructor for class org.apache.hive.service.cli.RowBasedSet
 
RowBasedSet(TRowSet) - Constructor for class org.apache.hive.service.cli.RowBasedSet
 
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
 
rowContainerStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The standard ObjectInspectors for the row container.
rowCount() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
rowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
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.
rowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
rowCountMap - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
rowDeleted() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
rowFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rowFormat - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.StorageFormatDesc
 
rowFormatDelimited() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rowFormatSerde() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ROWID - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
ROWID - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
rowIdMapping - Variable in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
rowIndexStride(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Set the distance between entries in the row index.
ROWINDEXSTRIDE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
rowInserted() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
rowIter() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
rowList - Variable in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
ROWOFFSET - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
rowOutWriters - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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.
rows() - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
rows(boolean[]) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
rows(long, long, boolean[]) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
rows(long, long, boolean[], SearchArgument, String[]) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
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
 
rowSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
RowSet - Interface in org.apache.hive.service.cli
 
RowSetFactory - Class in org.apache.hive.service.cli
 
RowSetFactory() - Constructor for class org.apache.hive.service.cli.RowSetFactory
 
rowsForwarded(int, int) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
rowsOptions(Reader.Options) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that uses the options given.
rowsOptions(Reader.Options) - Method in class org.apache.hadoop.hive.ql.io.orc.ReaderImpl
 
rowToProcess(WindowFunctionDef) - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
rowUpdated() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
rp - Variable in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
RPAREN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
RPAREN - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
Rpc - Class in org.apache.hive.spark.client.rpc
Encapsulates the RPC functionality.
Rpc.Listener - Interface in org.apache.hive.spark.client.rpc
 
RPC_SASL_OPT_PREFIX - Static variable in class org.apache.hive.spark.client.rpc.RpcConfiguration
Prefix for other SASL options.
rpcClosed(Rpc) - Method in interface org.apache.hive.spark.client.rpc.Rpc.Listener
 
RpcConfiguration - Class in org.apache.hive.spark.client.rpc
Definitions of configuration keys and default values for the RPC layer.
RpcConfiguration(Map<String, String>) - Constructor for class org.apache.hive.spark.client.rpc.RpcConfiguration
 
RpcDispatcher - Class in org.apache.hive.spark.client.rpc
An implementation of ChannelInboundHandler that dispatches incoming messages to an instance method based on the method signature.
RpcDispatcher() - Constructor for class org.apache.hive.spark.client.rpc.RpcDispatcher
 
RpcException - Exception in org.apache.hive.spark.client.rpc
 
RpcServer - Class in org.apache.hive.spark.client.rpc
An RPC server.
RpcServer(Map<String, String>) - Constructor for class org.apache.hive.spark.client.rpc.RpcServer
 
rproc - Variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
rrClass - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
rrConstructor - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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.cli.CliDriver
 
run(String[]) - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
run() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
run() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
This method scans the SessionItem collection.
run() - Method in class org.apache.hadoop.hive.metastore.events.EventCleanerTask
 
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.MergeFileTezProcessor
 
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(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.CryptoProcessor
 
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.ListResourceProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.ReloadProcessor
 
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(FsShell, String[]) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
run() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager.ExpiredTokenRemover
 
run(String) - Method in class org.apache.hive.beeline.Commands
Run a script from the specified file.
run() - Method in class org.apache.hive.beeline.util.QFileClient
 
run() - Method in class org.apache.hive.common.util.StreamPrinter
 
run(String) - Method in class org.apache.hive.hcatalog.cli.HCatDriver
 
run(String, String) - Method in class org.apache.hive.hcatalog.templeton.CompleteDelegator
 
run(String, String) - Method in class org.apache.hive.hcatalog.templeton.DeleteDelegator
 
run(String, List<String>, Map<String, String>) - Method in interface org.apache.hive.hcatalog.templeton.ExecService
 
run(String, List<String>, Map<String, String>) - Method in class org.apache.hive.hcatalog.templeton.ExecServiceImpl
Run the program synchronously as the given user.
run(String, String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.HcatDelegator
Run the local hcat executable.
run(String, Map<String, Object>, String, String, List<String>, List<String>, String, String, String, String, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.HiveDelegator
 
run(String, Map<String, Object>, String, String, String, String, List<String>, List<String>, String, String, boolean, String, boolean, Boolean, LauncherDelegator.JobType) - Method in class org.apache.hive.hcatalog.templeton.JarDelegator
 
run(String, boolean) - Method in class org.apache.hive.hcatalog.templeton.ListDelegator
 
run() - Method in class org.apache.hive.hcatalog.templeton.Main
 
run(String, Map<String, Object>, String, String, List<String>, String, String, String, boolean, String, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.PigDelegator
 
run(String, Map<String, Object>, String, String, String, String, String, String, boolean, Boolean, String) - Method in class org.apache.hive.hcatalog.templeton.SqoopDelegator
 
run(String, String) - Method in class org.apache.hive.hcatalog.templeton.StatusDelegator
 
run(String, Map<String, Object>, List<String>, String, String, String, String, String, List<String>, String, List<String>, List<String>, List<String>, String, String, String, boolean, Boolean, LauncherDelegator.JobType) - Method in class org.apache.hive.hcatalog.templeton.StreamingDelegator
 
run() - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
Run the cleanup loop.
run(Mapper<NullWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hive.hcatalog.templeton.tool.LaunchMapper
 
run() - Method in class org.apache.hive.hcatalog.templeton.tool.LogRetriever
 
run(String[]) - Method in class org.apache.hive.hcatalog.templeton.tool.TempletonControllerJob
Enqueue the job and print out the job id for later collection.
run() - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
Run the cleanup loop.
run() - Method in class org.apache.hive.service.auth.HttpAuthUtils.HttpKerberosClientAction
 
run() - Method in class org.apache.hive.service.cli.operation.Operation
 
run(HiveSessionHookContext) - Method in interface org.apache.hive.service.cli.session.HiveSessionHook
 
run() - Method in class org.apache.hive.service.cli.thrift.ThriftBinaryCLIService
 
run() - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
run() - Method in class org.apache.hive.service.cli.thrift.ThriftHttpCLIService
Configure Jetty to serve http requests.
run() - Method in class org.apache.hive.service.CompositeService.CompositeServiceShutdownHook
 
run(Job<T>) - Method in interface org.apache.hive.spark.client.SparkClient
Asks the remote context to run a job immediately.
RUN_TASKS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
runAs - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
runAs - Variable in class org.apache.hive.hcatalog.templeton.LauncherDelegator
 
runAsync - Variable in class org.apache.hive.service.cli.operation.Operation
 
runBeeLine(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
runCommands(String[]) - Method in class org.apache.hive.beeline.BeeLine
 
runCommands(List<String>) - Method in class org.apache.hive.beeline.BeeLine
 
runDistCp(Path, Path, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
runDistCp(Path, Path, Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
runDistCp(Path, Path, Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Copies a source dir/file to a destination by orchestrating the copy between hdfs nodes.
runInternal() - Method in class org.apache.hive.service.cli.operation.GetCatalogsOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetColumnsOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetFunctionsOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetSchemasOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetTablesOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetTableTypesOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.GetTypeInfoOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.HiveCommandOperation
 
runInternal() - Method in class org.apache.hive.service.cli.operation.Operation
Implemented by subclass of Operation class to execute specific behaviors.
runInternal() - Method in class org.apache.hive.service.cli.operation.SQLOperation
 
runnable - Variable in class org.apache.hadoop.hive.hwi.HWISessionItem
 
runner - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
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.
runQueries(Connection, int) - Static method in class org.apache.hive.testutils.jdbc.HiveBurnInClient
 
runQuery() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
runQuery iterates the list of queries executing each query.
runSequential() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
Launches a task, and sets its exit value in the result variable.
runServer(int) - Method in class org.apache.hive.hcatalog.templeton.Main
 
runStatus - Variable in class org.apache.hadoop.hive.ql.exec.TaskResult
 
runtimeSerializationKryo - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
runUnlimited(String, List<String>, Map<String, String>) - Method in interface org.apache.hive.hcatalog.templeton.ExecService
 
runUnlimited(String, List<String>, Map<String, String>) - Method in class org.apache.hive.hcatalog.templeton.ExecServiceImpl
Run the program synchronously as the given user.

S

S3LogDeserializer - Class in org.apache.hadoop.hive.contrib.serde2.s3
S3LogDeserializer.
S3LogDeserializer() - Constructor for class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
S3LogStruct - Class in org.apache.hadoop.hive.contrib.serde2.s3
S3LogStruct.
S3LogStruct() - Constructor for class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
safeAdd(long, long) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Bounded addition - overflows become MAX_VALUE
safeMult(long, double) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Bounded multiplication - overflows become MAX_VALUE
safeMult(long, long) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Bounded multiplication - overflows become MAX_VALUE
sameKeys(List<ExprNodeDesc>, List<ExprNodeDesc>, Operator<?>, Operator<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
sameRowSchema(Operator<?>, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
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
 
sampleDimension - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
sampleFraction - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
sampleNum - Variable in 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
 
sampleURL - Variable in class org.apache.hive.beeline.DriverInfo
 
SampleURLHook - Class in org.apache.hadoop.hive.contrib.metastore.hooks
First returns a url for a blank DB, then returns a URL for the original DB.
SampleURLHook() - Constructor for class org.apache.hadoop.hive.contrib.metastore.hooks.SampleURLHook
 
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
 
SARG_PUSHDOWN - Static variable in class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
SASL_ENABLED - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
SaslQOP - Enum in org.apache.hive.service.auth
Possible values of SASL quality-of-protection value.
saslQop - Variable in enum org.apache.hive.service.auth.SaslQOP
 
satisfies(RelTrait) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelDistribution
 
save(String) - Method in class org.apache.hive.beeline.Commands
 
saveField(TempletonStorage.Type, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
saveField(TempletonStorage.Type, String, String, String) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
Save a single key/value pair for a specific job id.
saveField(TempletonStorage.Type, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
saveSession(Driver.QueryState) - Method in class org.apache.hadoop.hive.ql.Driver
 
sc() - Method in interface org.apache.hive.spark.client.JobContext
The shared SparkContext instance.
scale() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
scale - Variable in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
scale() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Default implementation.
scale() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveDecimalObjectInspector
 
scale() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
The scale of the underlying data.
scale() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
SCALE - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
SCALE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
scaleByPowerOfTen(int) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
scaleDownFiveDestructive(short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Scale down the value for 5**tenScale (this := this / 5**tenScale).
scaleDownTen(SignedInt128, SignedInt128, short) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
scaleDownTenDestructive(short) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Scale down the value for 10**tenScale (this := this / 10**tenScale).
scaleDownTenDestructive(short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Scale down the value for 10**tenScale (this := this / 10**tenScale).
scaleReader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DecimalTreeReader
 
scaleUpFiveDestructive(short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Scale up the value for 5**tenScale (this := this * 5**tenScale).
scaleUpTen(SignedInt128, SignedInt128, short) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
scaleUpTenDestructive(short) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Scale up the value for 10**tenScale (this := this * 10**tenScale).
scaleUpTenDestructive(short) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Scale up the value for 10**tenScale (this := this * 10**tenScale).
scan(String) - Method in class org.apache.hive.beeline.Commands
 
schedule(Runnable) - Method in class org.apache.hive.testutils.junit.runners.model.ConcurrentScheduler
 
SchedulerShim - Interface in org.apache.hadoop.hive.shims
Shim for Fair scheduler HiveServer2 uses fair scheduler API to resolve the queue mapping for non-impersonation mode.
Schema - Class in org.apache.hadoop.hive.metastore.api
 
Schema() - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
 
Schema(List<FieldSchema>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
 
Schema(Schema) - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
Performs a deep copy on other.
Schema._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SCHEMA_DOC - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SCHEMA_LITERAL - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SCHEMA_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SCHEMA_NAMESPACE - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SCHEMA_NONE - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
 
SCHEMA_RETRIEVER - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SCHEMA_URL - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils
Deprecated.
SchemaAwareCompressionInputStream - Class in org.apache.hadoop.hive.ql.io
SchemaAwareCompressionInputStream adds the ability to inform the compression stream what column is being read.
SchemaAwareCompressionInputStream(InputStream) - Constructor for class org.apache.hadoop.hive.ql.io.SchemaAwareCompressionInputStream
 
SchemaAwareCompressionOutputStream - Class in org.apache.hadoop.hive.ql.io
SchemaAwareCompressionOutputStream adds the ability to inform the comression stream the current column being compressed.
SchemaAwareCompressionOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hive.ql.io.SchemaAwareCompressionOutputStream
 
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
 
scratchBatch - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
scratchlcv - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BinaryTreeReader
 
script(String) - Method in class org.apache.hive.beeline.Commands
Save or stop saving a script to a file
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 environment.
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.
seal() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
 
seal() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
seal() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
seal() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
seal() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
Indicates to the container that the puts have ended; table is now r/o.
seal() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
seal() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
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.TruthValue - Enum in org.apache.hadoop.hive.ql.io.sarg
The potential result sets of logical operations.
SearchArgumentFactory - Class in org.apache.hadoop.hive.ql.io.sarg
A factory for creating SearchArguments.
SearchArgumentFactory() - Constructor for class org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory
 
searchCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
searchCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
second - Variable in class org.apache.hive.hcatalog.data.Pair
 
SECONDARY_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
SECONDARY = 5;
secondaryPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
secondarySeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
secondsToNanoseconds(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
secretManager - Variable in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
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
 
SecureProxySupport - Class in org.apache.hive.hcatalog.templeton
Helper class to run jobs using Kerberos security.
SecureProxySupport() - Constructor for class org.apache.hive.hcatalog.templeton.SecureProxySupport
 
seek(long) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFSequenceFileRecordReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.InStream
 
seek(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BinaryTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BooleanTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ByteTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DateTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DecimalTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DoubleTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.FloatTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.IntTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.LongTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.ShortTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDictionaryTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDirectTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TimestampTreeReader
 
seek(PositionProvider) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
 
seek(long) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
seek(long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Set the current byte position in the input file.
seek(long) - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
seek(long) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
seek(int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Set the current position.
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
 
selectClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
selected - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
selectedInUse - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
selectExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
selectExpressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectExpressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
selectItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
selectList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
SelectOperator - Class in org.apache.hadoop.hive.ql.exec
Select operator implementation.
SelectOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SelectOperator
 
selectStatement(boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectStatementWithCTE() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectTrfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectTrfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
SemanticAnalyzer.GenericUDAFInfo - Class in org.apache.hadoop.hive.ql.parse
Class to store GenericUDAF related information.
SemanticAnalyzer.GenericUDAFInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer.GenericUDAFInfo
 
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
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
send(HCatEventMessage, String) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
send(HCatEventMessage, String, int) - Method in class org.apache.hive.hcatalog.listener.NotificationListener
 
send_abort_txn(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_dynamic_partitions(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partition_with_environment_context(Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partitions_pspec(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partitions_req(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_function(String, String, Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_partition_with_environment_context(String, String, Partition, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_partitions(String, String, List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_table_with_cascade(String, String, Table, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_table_with_environment_context(String, String, Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_append_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_append_partition_by_name_with_environment_context(String, String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_append_partition_with_environment_context(String, String, List<String>, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_CancelDelegationToken(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_CancelOperation(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_check_lock(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_clean() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_CloseOperation(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_CloseSession(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_commit_txn(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_compact(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_database(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_function(Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_role(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_table_with_environment_context(Table, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_type(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_delete_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_delete_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_database(String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_function(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition_by_name_with_environment_context(String, String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition_with_environment_context(String, String, List<String>, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partitions_req(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_role(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_table_with_environment_context(String, String, boolean, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_exchange_partition(Map<String, String>, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_execute(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_ExecuteStatement(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_fetchAll() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_fetchN(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_fetchOne() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_FetchResults(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_fire_listener_event(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_aggr_stats_for(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_current_notificationEventId() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_databases(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_delegation_token(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_fields_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_function(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_functions(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_next_notification(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_open_txns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_open_txns_info() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_part_specs_by_filter(String, String, String, int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_column_statistics(String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_by_expr(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_by_names(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_pspec(String, String, int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_statistics_req(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_principals_in_role(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_schema_with_environment_context(String, String, EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_table(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_table_column_statistics(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_table_names_by_filter(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_table_objects_by_name(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_table_statistics_req(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_tables(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_type_all(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_GetCatalogs(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_GetColumns(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_GetDelegationToken(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_GetFunctions(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_GetInfo(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_getMetaConf(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_GetOperationStatus(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_getQueryPlan() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_GetResultSetMetadata(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_GetSchemas(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_GetTables(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_GetTableTypes(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_GetTypeInfo(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_grant_revoke_privileges(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_grant_revoke_role(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_heartbeat(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_heartbeat_txn_range(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_lock(LockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_open_txns(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_OpenSession(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_partition_name_has_valid_characters(List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_rename_partition(String, String, List<String>, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_RenewDelegationToken(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.Client
 
send_revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_set_aggr_stats_for(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_set_ugi(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_setMetaConf(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_show_compact(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_show_locks(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_unlock(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_update_partition_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_update_table_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
Senum() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
SenumDef() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
SenumDefList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
SEPARATORCHAR - Static variable in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
separators - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
SEQUENCEFILE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
SEQUENCEFILE_INPUT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
SEQUENCEFILE_OUTPUT - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
SequenceFileInputFormatChecker - Class in org.apache.hadoop.hive.ql.io
SequenceFileInputFormatChecker.
SequenceFileInputFormatChecker() - Constructor for class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
SequenceFileStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
SequenceFileStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.SequenceFileStorageFormatDescriptor
 
SerDe - Interface in org.apache.hadoop.hive.serde2
Deprecated.
serde - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
serdeConstants - Class in org.apache.hadoop.hive.serde
 
serdeConstants() - Constructor for class org.apache.hadoop.hive.serde.serdeConstants
 
SerDeException - Exception in org.apache.hadoop.hive.serde2
Generic exception class for SerDes.
SerDeException() - Constructor for exception org.apache.hadoop.hive.serde2.SerDeException
 
SerDeException(String) - Constructor for exception org.apache.hadoop.hive.serde2.SerDeException
 
SerDeException(Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.SerDeException
 
SerDeException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.serde2.SerDeException
 
SerDeInfo - Class in org.apache.hadoop.hive.metastore.api
 
SerDeInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
SerDeInfo(String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
SerDeInfo(SerDeInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
Performs a deep copy on other.
SerDeInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
serdeLib(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for SerDe class name.
serdeParam(String, String) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
serdeParam(String, String) - Method in class org.apache.hive.hcatalog.api.HCatTable
 
serdeParams - Variable in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
serdeParams - Variable in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
serdeParams - Variable in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
serdeParams - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
serdeParams(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatTable
 
SerDeSpec - Annotation Type in org.apache.hadoop.hive.serde2
 
SerDeStats - Class in org.apache.hadoop.hive.serde2
 
SerDeStats() - Constructor for class org.apache.hadoop.hive.serde2.SerDeStats
 
SerDeStatsStruct - Interface in org.apache.hadoop.hive.serde2
 
SerDeUtils - Class in org.apache.hadoop.hive.serde2
SerDeUtils.
SERIALIZATION_CLASS - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_DDL - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_ENCODING - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_EXTEND_ADDITIONAL_NESTING_LEVELS - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
SERIALIZATION_EXTEND_NESTING_LEVELS - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_LAST_COLUMN_TAKES_REST - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_LIB - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_NULL_FORMAT - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_SORT_ORDER - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SERIALIZATION_TYPE - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDe
Defines the type for a column.
SERIALIZATION_USE_JSON_OBJECTS - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SerializationContextImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
Deprecated.
The JobConf key of the SerializationContext to use.
SerializationError - Exception in org.apache.hive.hcatalog.streaming
 
SerializationError(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.SerializationError
 
SerializationImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
Deprecated.
The JobConf keys for the Serialization implementation.
SerializationSubclassKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Deprecated.
The JobConf keys for the Class that is being deserialized.
serialize() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
serialize(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.DoubleCompare
 
serialize(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.IntCompare
 
serialize(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LongCompare
 
serialize(byte[]) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.PrimitiveComparison
 
serialize(byte[]) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.contrib.serde2.RegexSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.HBaseRowSerializer
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
serialize(OutputStream, Object) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
serialize(Object) - Static method in class org.apache.hadoop.hive.ql.exec.spark.KryoSerializer
 
serialize(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
serialize(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringCommon
 
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(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
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(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.AbstractSerDe
Serialize an object by navigating inside the Object with the ObjectInspector.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.AbstractSerializer
Serialize an object by navigating inside the Object with the ObjectInspector.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
Serialize a row of data.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
serialize The way to serialize a Thrift "table" which in thrift land is really a function and thus this class's name.
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
serialize(Object, ObjectInspector, TProtocol) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
serialize(ByteStream.Output, Object, ObjectInspector, byte[], int, Text, boolean, byte, boolean[]) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Serialize the row into the StringBuilder.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
Serialize an object to a byte buffer in a binary compact way.
serialize(ByteStream.RandomAccessOutput, Object, ObjectInspector, boolean, LazyBinarySerDe.BooleanRef) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
A recursive function that serialize an object to a byte buffer based on its object inspector.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.NullStructSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.OpenCSVSerde
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.RegexSerDe
 
serialize(Object, ObjectInspector) - Method in interface org.apache.hadoop.hive.serde2.Serializer
Deprecated.
Serialize an object by navigating inside the Object with the ObjectInspector.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
serialize(Serializable) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
 
serialize(Object, ObjectInspector) - Method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
The purpose of the serialize method is to turn an object-representation with a provided ObjectInspector into a Writable format, which the underlying layer can then use to write out.
serialize(Object, ObjectInspector) - Method in class org.apache.hive.hcatalog.data.JsonSerDe
Given an object and object inspector pair, traverse the object and generate a Text representation of the object.
SERIALIZE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
serializeBytes(ByteStream.Output, byte[], int, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeBytes(ByteStream.Output, byte[], int, int, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeColumnMapping(HiveAccumuloColumnMapping, ObjectInspector, Object, Mutation) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
serializeColumnMapping(HiveAccumuloMapColumnMapping, ObjectInspector, Object, Mutation) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
Serialize the Hive Map into an Accumulo row
serializeCommand(Command) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Command implements Writable, but that's not terribly easy to use compared to String, even if it plugs in easily into the rest of Hadoop.
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.
serializeDouble(ByteStream.Output, double, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializedSize - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
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.
serializeField(ByteStream.Output, Object, ObjectInspector, LazySerDeParameters) - Method in class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
 
serializeField(ByteStream.Output, Object, ObjectInspector, LazySerDeParameters) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
serializeField(Object, ObjectInspector) - Static method in class org.apache.hive.hcatalog.data.HCatRecordSerDe
Return underlying Java Object from an object-representation that is readable by a provided ObjectInspector.
serializeFloat(ByteStream.Output, float, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeHiveDecimal(ByteStream.Output, HiveDecimal, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeHiveIntervalDayTime(ByteStream.Output, HiveIntervalDayTime, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeHiveIntervalYearMonth(ByteStream.Output, HiveIntervalYearMonth, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeInt(ByteStream.Output, int, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeJobConf(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.KryoSerializer
 
serializeKey(Object, StructField) - Method in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
serializeKey(Object, StructField) - Method in interface org.apache.hadoop.hive.hbase.HBaseKeyFactory
serialize hive object in internal format of custom key
serializeLong(ByteStream.Output, long, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeObject(Serializable) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
serializePartial(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
serializePartition(HCatPartition) - Method in class org.apache.hive.hcatalog.api.HCatClient
Serializer for HCatPartition.
serializePartition(HCatPartition) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
serializePartitions(List<HCatPartition>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Serializer for a list of HCatPartition.
serializePartitions(List<HCatPartition>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
serializePartitionSpec(HCatPartitionSpec) - Method in class org.apache.hive.hcatalog.api.HCatClient
Serializer for HCatPartitionSpec.
serializePartitionSpec(HCatPartitionSpec) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
serializePlan(Object, OutputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serializes the plan.
serializer - Variable in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
serializer - Variable in class org.apache.hadoop.hive.hbase.DefaultHBaseKeyFactory
 
serializer - Variable in class org.apache.hadoop.hive.ql.exec.AppMasterEventOperator
 
serializer - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
Serializer - Interface in org.apache.hadoop.hive.serde2
Deprecated.
serializeRow(ByteStream.Output, Object[], List<ObjectInspector>, boolean[]) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
Serializes row to output.
serializeRowId(Object, StructField, ByteStream.Output) - Method in interface org.apache.hadoop.hive.accumulo.serde.AccumuloRowIdFactory
serialize hive object in internal format of custom key
serializeRowId(Object, StructField, ColumnMapping) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
Serialize an Accumulo rowid
serializeRowId(Object, StructField, ByteStream.Output) - Method in class org.apache.hadoop.hive.accumulo.serde.DefaultAccumuloRowIdFactory
 
serializeShort(ByteStream.Output, short, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeStruct(ByteStream.Output, Object[], List<ObjectInspector>, boolean[]) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeStruct(ByteStream.RandomAccessOutput, Object[], List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
 
serializeTable(HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatClient
Serializer for HCatTable.
serializeTable(HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
serializeTimestampWritable(ByteStream.Output, TimestampWritable, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
serializeTo(int[], int, int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given array, putting the required number of ints for the given precision.
serializeTo(IntBuffer, int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given ByteBuffer, putting the required number of ints for the given precision.
serializeTo(IntBuffer, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given ByteBuffer, putting the required number of ints for the given precision.
serializeTo(int[], int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given array, putting the required number of ints for the given precision.
serializeTo128(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given integers, putting 128+32 bits of data (full range).
serializeTo128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given ByteBuffer, putting 128+32 bits of data (full range).
serializeTo128(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to the given array, putting 128 bits data (full ranges).
serializeTo128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to ByteBuffer, putting 128 bits data (full ranges).
serializeTo128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given ByteBuffer, putting 128 bits data (full ranges).
serializeTo128(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given array, putting 128 bits data (full ranges).
serializeTo32(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given integers, putting only 32+32 bits of data.
serializeTo32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given ByteBuffer, putting only 32+32 bits of data.
serializeTo32(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to the given array, putting only 32 bits data.
serializeTo32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to ByteBuffer, putting only 32 bits data.
serializeTo32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given ByteBuffer, putting only 32 bits data.
serializeTo32(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given array, putting only 32 bits data.
serializeTo64(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given integers, putting only 64+32 bits of data.
serializeTo64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given ByteBuffer, putting only 64+32 bits of data.
serializeTo64(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to the given array, putting only 64 bits data.
serializeTo64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to ByteBuffer, putting only 64 bits data.
serializeTo64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given ByteBuffer, putting only 64 bits data.
serializeTo64(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given array, putting only 64 bits data.
serializeTo96(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given integers, putting only 96+32 bits of data.
serializeTo96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Serialize this object to the given ByteBuffer, putting only 96+32 bits of data.
serializeTo96(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to the given array, putting only 96 bits data.
serializeTo96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Serializes the value of this object to ByteBuffer, putting only 96 bits data.
serializeTo96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given ByteBuffer, putting only 96 bits data.
serializeTo96(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Serialize this object to the given array, putting only 96 bits data.
serializeValue(Object, StructField) - Method in class org.apache.hadoop.hive.hbase.struct.AvroHBaseValueFactory
 
serializeValue(Object, StructField) - Method in class org.apache.hadoop.hive.hbase.struct.DefaultHBaseValueFactory
 
serializeValue(Object, StructField) - Method in interface org.apache.hadoop.hive.hbase.struct.HBaseValueFactory
Serialize the given hive object
serializeVector(ByteStream.Output, VectorHashKeyWrapper, VectorExpressionWriter[], VectorHashKeyWrapperBatch, boolean[], boolean[]) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
Serializes row to output for vectorized path.
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
 
serializeWrite(VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
SerializeWrite - Interface in org.apache.hadoop.hive.serde2.fast
 
serializeWriteNoNulls(VectorizedRowBatch, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
Server - Class in org.apache.hive.hcatalog.templeton
The Templeton Web API server.
Server() - Constructor for class org.apache.hive.hcatalog.templeton.Server
 
server - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
SERVER_HTTP_URL - Static variable in class org.apache.hive.service.auth.HttpAuthUtils.HttpKerberosClientAction
 
SERVER_LISTEN_ADDRESS_KEY - Static variable in class org.apache.hive.spark.client.rpc.RpcConfiguration
 
SERVER_VERSION - Static variable in class org.apache.hive.service.cli.CLIService
 
serverEventHandler - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
serverIPAddress - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
ServerUtils - Class in org.apache.hadoop.hive.common
ServerUtils (specific to HiveServer version 1)
ServerUtils() - Constructor for class org.apache.hadoop.hive.common.ServerUtils
 
Service() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
Service - Interface in org.apache.hive.service
Service.
Service.STATE - Enum in org.apache.hive.service
Service states
ServiceException - Exception in org.apache.hive.service
ServiceException.
ServiceException(Throwable) - Constructor for exception org.apache.hive.service.ServiceException
 
ServiceException(String) - Constructor for exception org.apache.hive.service.ServiceException
 
ServiceException(String, Throwable) - Constructor for exception org.apache.hive.service.ServiceException
 
ServiceOperations - Class in org.apache.hive.service
ServiceOperations.
ServiceStateChangeListener - Interface in org.apache.hive.service
ServiceStateChangeListener.
ServiceUtils - Class in org.apache.hive.service
 
ServiceUtils() - Constructor for class org.apache.hive.service.ServiceUtils
 
SERVLET_PATH - Static variable in class org.apache.hive.hcatalog.templeton.Main
 
session - Variable in class org.apache.hive.hcatalog.listener.NotificationListener
 
SessionHandle - Class in org.apache.hive.service.cli
SessionHandle.
SessionHandle(TProtocolVersion) - Constructor for class org.apache.hive.service.cli.SessionHandle
 
SessionHandle(TSessionHandle) - Constructor for class org.apache.hive.service.cli.SessionHandle
 
SessionHandle(TSessionHandle, TProtocolVersion) - Constructor for class org.apache.hive.service.cli.SessionHandle
 
SessionHiveMetaStoreClient - Class in org.apache.hadoop.hive.ql.metadata
 
sessionId - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
SessionManager - Class in org.apache.hive.service.cli.session
SessionManager.
SessionManager(HiveServer2) - Constructor for class org.apache.hive.service.cli.session.SessionManager
 
SessionPropertiesListener - Class in org.apache.hadoop.hive.metastore
It handles the changed properties in the change event.
SessionPropertiesListener(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.SessionPropertiesListener
 
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.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(String, Object) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
set(int, int, int, int, int) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
set(long, int) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
set(BigDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
set(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
set(int, int) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
set(int) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
set(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
set(int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
set(BytesBytesMultiHashMap, long, boolean, long) - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.Result
Set internal values for reading the values after finding a key.
set(int, Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
set(int, HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
set(int, HiveDecimal) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
set(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashMultiSet.HashMultiSetResult
 
set(VectorMapJoinFastValueStore, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
set(int, Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
set(int, Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
set(int, Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
set(int, Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
set(int, Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
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(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(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead
 
set(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
set(int, BytesRefWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Set the BytesRefWritable at the specified position with the specified BytesRefWritable.
set(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
readFields() will corrupt the array.
set(LazyDecompressionCallback, int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
readFields() will corrupt the array.
set(byte[], int, int) - Method in interface org.apache.hadoop.hive.serde2.fast.DeserializeRead
 
set(ByteStream.Output) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
set(int) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
Set the DateWritable based on the days since epoch date.
set(Date) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
Set the DateWritable based on the year/month/day of the date in the local timezone.
set(DateWritable) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
set(HiveChar) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(String) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(HiveCharWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(HiveCharWritable, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(HiveChar, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(String, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
set(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
set(HiveDecimal, int, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
set(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
set(byte[], int) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
set(int, int, int, int, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
set(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
set(HiveIntervalDayTimeWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
set(long, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
set(int, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
set(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
set(HiveIntervalYearMonthWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
set(int) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
set(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(String) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(HiveVarcharWritable) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(HiveVarcharWritable, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(HiveVarchar, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(String, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
set(short) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
set(byte[], int) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
set(Timestamp) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
set(TimestampWritable) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
set(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead
 
set(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
set(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead
 
set(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
set(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.StringWrapper
 
set(Object, byte[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
set(Object, BytesWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBinaryObjectInspector
 
set(Object, boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
set(Object, byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
set(Object, Date) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
set(Object, DateWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDateObjectInspector
 
set(Object, double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
set(Object, float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
set(Object, HiveChar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveCharObjectInspector
 
set(Object, byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
set(Object, HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
set(Object, HiveDecimalWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveDecimalObjectInspector
 
set(Object, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalDayTimeWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
set(Object, HiveIntervalYearMonthWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveIntervalYearMonthObjectInspector
 
set(Object, HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaHiveVarcharObjectInspector
 
set(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
set(Object, long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
set(Object, short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
set(Object, Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
set(Object, Timestamp) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
set(Object, byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
set(Object, TimestampWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaTimestampObjectInspector
 
set(Object, byte[]) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBinaryObjectInspector
Set the object with the value.
set(Object, BytesWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBinaryObjectInspector
Set the object with the value.
set(Object, boolean) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableBooleanObjectInspector
Set the object with the value.
set(Object, byte) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableByteObjectInspector
Set the object with the value.
set(Object, Date) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableDateObjectInspector
 
set(Object, DateWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableDateObjectInspector
 
set(Object, double) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableDoubleObjectInspector
Set the object with the value.
set(Object, float) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableFloatObjectInspector
Set the object with the value.
set(Object, HiveChar) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveCharObjectInspector
 
set(Object, String) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveCharObjectInspector
 
set(Object, byte[], int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveDecimalObjectInspector
 
set(Object, HiveDecimal) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveDecimalObjectInspector
 
set(Object, HiveDecimalWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveDecimalObjectInspector
 
set(Object, HiveIntervalDayTime) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalDayTimeWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalYearMonth) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalYearMonthObjectInspector
 
set(Object, HiveIntervalYearMonthWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveIntervalYearMonthObjectInspector
 
set(Object, HiveVarchar) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveVarcharObjectInspector
 
set(Object, String) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableHiveVarcharObjectInspector
 
set(Object, int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableIntObjectInspector
Set the object with the value.
set(Object, long) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableLongObjectInspector
Set the object with the value.
set(Object, short) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableShortObjectInspector
Set the object with the value.
set(Object, Text) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableStringObjectInspector
Set the object with the value.
set(Object, String) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableStringObjectInspector
Set the object with the value.
set(Object, byte[], int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableTimestampObjectInspector
 
set(Object, Timestamp) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableTimestampObjectInspector
 
set(Object, TimestampWritable) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.SettableTimestampObjectInspector
 
set(Object, byte[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
set(Object, BytesWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBinaryObjectInspector
 
set(Object, boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableBooleanObjectInspector
 
set(Object, byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
set(Object, Date) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
set(Object, DateWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
set(Object, double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDoubleObjectInspector
 
set(Object, float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableFloatObjectInspector
 
set(Object, HiveChar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
set(Object, byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
set(Object, HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
set(Object, HiveDecimalWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
set(Object, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalDayTimeWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
set(Object, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
set(Object, HiveIntervalYearMonthWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
set(Object, HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
set(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableIntObjectInspector
 
set(Object, long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableLongObjectInspector
 
set(Object, short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableShortObjectInspector
 
set(Object, Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
set(Object, byte[], int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
set(Object, Timestamp) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
set(Object, TimestampWritable) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
set(Object, int, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Set the element at index.
set(Object, int, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
set(String) - Method in class org.apache.hive.beeline.Commands
 
set(int) - Method in class org.apache.hive.common.util.BloomFilter.BitSet
Sets the bit at specified index.
set(int, Object) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
set(String, HCatSchema, Object) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
set(String, HCatSchema, Object) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
set(int, Object) - Method in interface org.apache.hive.hcatalog.data.HCatRecordable
Sets the field at the specified index.
set(int, Object) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
set(String, HCatSchema, Object) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
set_aggr_stats_for(SetPartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
set_aggr_stats_for(SetPartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
set_aggr_stats_for(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
set_aggr_stats_for(SetPartitionsStatsRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
set_aggr_stats_for(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
SET_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
set_ugi(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_ugi_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
set_ugi(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_ugi_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
set_ugi(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
set_ugi(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
set_ugi(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setAbort(boolean) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
setAbort(boolean) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
setAbort(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer.CorrelationNodeProcCtx
 
setAborted(Set<Long>) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
setAbortedIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
setAcceptsFields(boolean) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
 
setAccumuloConnectorInfo(JobConf, String, AuthenticationToken) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
setAccumuloMockInstance(JobConf, String) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
setAccumuloZooKeeperInstance(JobConf, String, String, boolean) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
setAcidOperation(AcidUtils.Operation) - Method in class org.apache.hadoop.hive.ql.Context
 
setAcquiredat(long) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setAcquiredatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setActiveAuthorizer(Object) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAddPartitionDesc(AddPartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAddTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setAdjacencyList(List<Adjacency>) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setAdjacencyListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setAdjacencyType(AdjacencyType) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setAdjacencyTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setAfterCol(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
setAggParameterException(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
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
 
setAint(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAintIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.optimizer.index.RewriteCanApplyCtx
 
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
 
setAliasToNewAliasMap(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setAliasToOpInfo(Map<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setAliasToOpInfo(Map<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
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
 
setAllowDistinctFunctions(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setAllowStatefulFunctions(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setAllStructFieldNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
For java serialization use only.
setAllStructFieldTypeInfos(ArrayList<TypeInfo>) - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
For java serialization use only.
setAllUnionObjectTypeInfos(List<TypeInfo>) - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
For java serialization use only.
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
 
setAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setAnalyzeRewrite(BaseSemanticAnalyzer.AnalyzeRewriteContext) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setAnalyzeRewrite(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setAnalyzeRewrite(BaseSemanticAnalyzer.AnalyzeRewriteContext) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setAnalyzeRewrite(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setAndExprStats(Statistics) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
setAnsiSqlArithmetic(boolean) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
setAppend(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
setAppend(ByteStream.Output) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
setAppend(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
setAppend(ByteStream.Output) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
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.gen.IfExprDoubleColumnDoubleColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
setArg2Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
setArg2Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
setArg2Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
setArg2Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
setArg2Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
setArg2Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
setArg2Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
setArg2Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
setArg3Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
setArg3Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
setArg3Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
setArg3Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
setArg3Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
setArg3Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
setArg3Scalar(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
setArg3Scalar(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
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
 
setArray(int, Array) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setArray(int, Array) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setArrayEntry(TArrayTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setAsciiStream(String, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(String, InputStream, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setAsciiStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setAST(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
setAstNode(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
setAString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
setAStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
setAstStringTree(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setAttribute(Attribute) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
setAttributes(AttributeList) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
setAttributes(Map<String, Map<String, Map<String, PropValueUnion>>>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAuth(HWIAuth) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
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
 
setAuthorize(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setAuthorizer(HiveAuthorizationProvider) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAutoCommit(boolean) - Method in class org.apache.hive.jdbc.HiveConnection
 
setAutoReduceParallelism(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setAuxJars(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setAvgColLenIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setAvgColLenIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setBackgroundHandle(Future<?>) - Method in class org.apache.hive.service.cli.operation.Operation
 
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
 
setBadRecords(List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMDatabaseURIRetVal
 
setBadRecords(List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMStorageDescriptorTblURIRetVal
 
setBadRecords(List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdatePropURIRetVal
 
setBadRecords(List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateSerdeURIRetVal
 
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
 
setBase_tbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setBase_tbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
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
 
setBaseSrc(String[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setBaseSrc(String[]) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
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
 
setBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
setBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
setBatchOnEntry(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRowDynBatch
 
setBatchOnEntry(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRowDynBatch
 
setBatchSize(VectorizedRowBatch, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Reduce the batch size for a vectorized row batch
setBigDecimal(String, BigDecimal) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
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
 
setBinarySearching(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setBinarySortable(byte[], int) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
Given a byte[] that has binary sortable data, initialize the internal structures to hold that data
setBinaryStatistics(OrcProto.BinaryStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
setBinaryStatistics(OrcProto.BinaryStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BinaryStatistics binaryStatistics = 8;
setBinaryStats(BinaryColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setBinaryStats(Long, Long, Double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setBinaryStats(Long, Long, Double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setBinaryStream(String, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(String, InputStream, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBinaryStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBinaryVal(TBinaryColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setBinaryValue(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
setBit(int, int) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
setBitset(int, long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
repeated fixed64 bitset = 2;
setBlob(String, Blob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(String, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(int, Blob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(int, InputStream) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBlob(int, Blob) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBlob(int, InputStream) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBlob(int, InputStream, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBlockedFunction(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
setBlockPointer(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setBloomFilter(int, OrcProto.BloomFilter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
setBloomFilter(int, OrcProto.BloomFilter.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex.Builder
repeated .orc.proto.BloomFilter bloomFilter = 1;
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
 
setBoolean(String, HCatSchema, Boolean) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setBoolean(String, boolean) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBoolean(int, boolean) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBoolean(int, boolean) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBooleanStats(BooleanColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setBooleanStats(Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setBooleanStats(Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setBoolVal(TBoolColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setBoolVal(TBoolValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setBoolVar(Configuration, HiveConf.ConfVars, boolean) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setBoolVar(HiveConf.ConfVars, boolean) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setBucketColNames(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
setBucketCols(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setBucketCols(List<String>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setBucketColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
setBucketStatistics(OrcProto.BucketStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
setBucketStatistics(OrcProto.BucketStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.BucketStatistics bucketStatistics = 5;
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
 
setBuildDir(String) - Method in class org.apache.hadoop.hive.ant.GenVectorCode
 
setByte(String, HCatSchema, Byte) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setByte(String, byte) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setByte(int, byte) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setByte(int, byte) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setByteArray(String, HCatSchema, byte[]) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setBytes(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
setBytes(String, byte[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBytes(int, byte[]) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setBytes(int, byte[]) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setBytesValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setByteVal(TByteColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setByteVal(TByteValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setCallback(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
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
 
setCascade(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setCascade(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setCascadeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setCascadeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setCatalog(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
setCatalogName(String) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setCatalogName(String) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setCatalogName(String) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setCatalogName(String) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setCatalogNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setCatalogNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setCatalogNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setCatalogNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setCboInfo(String) - Method in class org.apache.hadoop.hive.ql.Context
 
setCboInfo(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setCboSucceeded(boolean) - Method in class org.apache.hadoop.hive.ql.Context
 
setCD(MColumnDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setCfg(Configuration) - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
setChar(String, HCatSchema, HiveChar) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setCharacterMaximumLength(int) - Method in class org.apache.hive.service.cli.TypeQualifiers
 
setCharacterStream(String, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(String, Reader, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
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<String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
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
 
setChildrenIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setChildTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setClassName(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setClassName(String) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setClassName(String) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setClassNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setCleanupScript(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setClearAggregatorStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setClient(TCLIService.Iface) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setClient_protocol(TProtocolVersion) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setClient_protocolIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setClientInfo(Properties) - Method in class org.apache.hive.jdbc.HiveConnection
 
setClientInfo(String, String) - Method in class org.apache.hive.jdbc.HiveConnection
 
setClientIp(String) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
setClientType(HiveAuthzSessionContext.CLIENT_TYPE) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
setClientUGI(UserGroupInformation) - Method in class org.apache.hadoop.hive.thrift.TUGIContainingTransport
 
setClob(String, Clob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(String, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(int, Clob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(int, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setClob(int, Clob) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setClob(int, Reader) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setCloneToWork(Map<BaseWork, BaseWork>) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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.
setClusterMode(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
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(String) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setCol(String) - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
setCol_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setCol_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setCol_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setCol_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setCol_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setCol_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setCol_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setCol_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setColIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
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(String) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setColName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setColName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setColName(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
setColName(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setColNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setColNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setColNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
setColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setColNamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setColNamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
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.gen.CastDateToBooleanViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.StringGroupColConcatStringScalar
 
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.StringScalarConcatStringGroupCol
 
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.gen.DateColAddIntervalDayTimeColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
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.StringGroupConcatColCol
 
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.gen.DateColAddIntervalDayTimeColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
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.StringGroupConcatColCol
 
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.metastore.api.StorageDescriptor
 
setCols(List<MFieldSchema>) - Method in class org.apache.hadoop.hive.metastore.model.MColumnDescriptor
 
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
 
setColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setColStats(List<ColumnStatisticsObj>) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
setColStats(List<ColumnStatistics>) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
setColStats(int, OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
setColStats(int, OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics.Builder
repeated .orc.proto.ColumnStatistics colStats = 1;
setColStats(ColumnStatsDesc) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
setColStatsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
setColStatsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
setColType(String) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setColType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setColType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setColType(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
setColType(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setColTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
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(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint32 column = 2;
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.metastore.api.HiveObjectRef
 
setColumnName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setColumnName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setColumnName(String) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setColumnName(String) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setColumnName(String) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setColumnNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setColumnNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setColumnNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
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.
setColumnNumber(Configuration, int) - Static method in class org.apache.hive.hcatalog.rcfile.RCFileMapReduceOutputFormat
Set number of columns into the given configuration.
setColumns(int, OrcProto.ColumnEncoding) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
setColumns(int, OrcProto.ColumnEncoding.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.ColumnEncoding columns = 2;
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.PrivilegeObjectDesc
 
setColumns(List<TColumn>) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setColumns(List<TColumnDesc>) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
setColumnsClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setColumnsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setColumnsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
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.
setColVals(List<TColumnValue>) - Method in class org.apache.hive.service.cli.thrift.TRow
 
setColValsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRow
 
setCommand(String) - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHookContext
 
setCommand(String) - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
setCommand(String) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
setCommand(String) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setCommandString(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
 
setCommandType(HiveOperation) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setComment(String) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setComment(String) - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
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
 
setComment(String) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setCommentIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setCommentIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setComments(String) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setCommentsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setCommonJoinTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setCompacts(List<ShowCompactResponseElement>) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
setCompactsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
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
 
setCompleteStatus(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setCompleteTaskList(List<TaskRunner>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setComponent(List<LockComponent>) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setComponentIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setCompressBufferSize(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
setCompressCodec(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressedIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setCompressedKeyLength(int) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setCompression(CompressionKind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
setCompression(OrcProto.CompressionKind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional .orc.proto.CompressionKind compression = 2;
setCompressionBlockSize(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 compressionBlockSize = 3;
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(Configuration) - Method in class org.apache.hadoop.hive.accumulo.AccumuloStorageHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.hbase.HBaseStorageHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEndFunctionListener
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.MetaStoreEventListener
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.MetaStoreInitListener
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.MetaStorePreEventListener
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Called whenever this object is instantiated using ReflectionUtils, and also on connection retries.
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
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.hooks.Redactor
Guranteed to be called before redactQuery is called
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
Deprecated.
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
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
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
setConf(Object, Configuration) - Static method in class org.apache.hive.common.util.ReflectionUtil
Check and set 'configuration' if necessary.
setConf(Configuration) - Method in enum org.apache.hive.hcatalog.common.HCatContext
Use the given configuration for optional behavior.
setConf(Configuration) - Method in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
 
setConfiguration(HiveConf) - Method in class org.apache.hive.service.cli.operation.Operation
 
setConfiguration(Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setConfiguration(Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setConfigurationIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setConfigurationIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setConfLookupNeeded(boolean) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
setConfName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowConfDesc
 
setConfOverlay(Map<String, String>) - Method in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
setConfOverlay(Map<String, String>) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setConfOverlayIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setConfValues(HiveConf) - Static method in class org.apache.hadoop.hive.metastore.txn.TxnDbUtil
Set up the configuration so it will use the DbTxnManager, concurrency will be set to true, and the JDBC configs will be set for putting the transaction and lock info in the embedded metastore.
setConnectorInfo(JobConf, String, AuthenticationToken) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
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
 
setConstantPropagateOption(ConstantPropagateProcCtx.ConstantPropagateOption) - Method in class org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx
 
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
 
setContentLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 contentLength = 2;
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
 
setCount(byte) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This setter is only for de-serialization, should not be used otherwise.
setCount(int, long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics.Builder
repeated uint64 count = 1 [packed = true];
setCountDistint(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setCounters(Counters) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setCpuMSec(long) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setCreated(long) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
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
 
setCreateTable(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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.metastore.api.Function
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setCreateTime(long) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
setCreateTime(long) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
setCreateTime(long) - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Setter for creation-time of a Partition.
setCreateTime(long) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
setCreateTime(long) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.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
 
setCTAS(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
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
 
setCurrentDate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentDate
 
setCurrentHostZnodePath(String) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setCurrentInputPath(Path) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setCurrentOperationLog(OperationLog) - Static method in class org.apache.hadoop.hive.ql.session.OperationLog
 
setCurrentReplicationState(String) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
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.HiveV1Authorizer
 
setCurrentRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
setCurrentRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
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
 
setCurrentTimestamp(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentTimestamp
 
setCurrentTxn(long) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setCurrentUser(Text) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCurrentUser
 
setCurrMapJoinOp(AbstractMapJoinOperator<? extends MapJoinDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setCurrTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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
 
setCursorName(String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setCursorName(String) - Method in class org.apache.hive.jdbc.HiveStatement
 
setCustomPath(String, OutputJobInfo) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatFileUtil
 
setD(Path) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setData(FireEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setData(HiveLockObject.HiveLockObjectData) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
setData(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
setDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setDatabase(Database) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setDatabaseIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
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
 
setDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setDataLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 dataLength = 3;
setDataLocation(Path) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDataSize(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setDate(String, HCatSchema, Date) - Method in class org.apache.hive.hcatalog.data.HCatRecord
Note that the proper way to construct a java.sql.Date for use with this object is Date.valueOf("1999-12-31").
setDate(String, Date) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDate(String, Date, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDate(int, Date) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDate(int, Date) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setDateStatistics(OrcProto.DateStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
setDateStatistics(OrcProto.DateStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DateStatistics dateStatistics = 7;
setDateStats(DateColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setDateStats(Long, Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDateStats(Long, Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDaysSinceEpoch(long) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
setDaysSinceEpochIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
setDb(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setDbIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the database name.
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Setter for name of the DB.
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
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.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
 
setDbName(String) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
setDbOpts(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
setDebugStream(PrintStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Set debug output.
setDecimal(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
setDecimal(String, HCatSchema, HiveDecimal) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setDecimalHighValue(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDecimalHighValue(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDecimalLowValue(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDecimalLowValue(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDecimalStatistics(OrcProto.DecimalStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
setDecimalStatistics(OrcProto.DecimalStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DecimalStatistics decimalStatistics = 6;
setDecimalStats(DecimalColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setDecimalStats(Long, Long, String, String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDecimalStats(Long, Long, String, String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDecimalValue(HiveDecimal) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setDefault() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
setDefaultAccumuloTableName(JobConf, String) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat
 
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.metastore.api.PartitionsByExprRequest
 
setDefaultPartitionName(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setDefaultPartitionNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
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
 
setDefaultValue(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setDefaultValueConverter(ObjectInspectorConverters.Converter) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setDefaultValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setDeferredRebuildIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDelegationToken(String) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
setDelegationToken(String) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
setDelegationToken(String) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
setDelegationTokenIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
setDelegationTokenIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
setDelegationTokenIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
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
 
setDescription(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setDescription(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setDescriptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setDescTblDesc(DescTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDest_db(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setDest_dbIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setDest_table_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setDest_table_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
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.
setDictionary(Dictionary) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
setDictionary(Dictionary) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedPrimitiveConverter
 
setDictionarySize(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional uint32 dictionarySize = 2;
setDir(String) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setDirect(byte[], int, int, BytesBytesMultiHashMap.Result) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.ReusableGetAdaptorDirectAccess
 
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
 
setDirectoryDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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
 
setDisplayName(String) - Method in class org.apache.hive.spark.counter.SparkCounter
 
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(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setDone() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
setDoSplitsGrouping(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setDouble(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
setDouble(String, HCatSchema, Double) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setDouble(String, double) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDouble(int, double) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setDouble(int, double) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setDoubleHighValue(Double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDoubleHighValue(double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDoubleLowValue(Double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDoubleLowValue(double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDoubleStatistics(OrcProto.DoubleStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
setDoubleStatistics(OrcProto.DoubleStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.DoubleStatistics doubleStatistics = 3;
setDoubleStats(DoubleColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setDoubleStats(Long, Long, Double, Double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setDoubleStats(Long, Long, Double, Double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setDoubleVal(TDoubleColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setDoubleVal(TDoubleValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setDoubleValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setDoubleValue(double) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
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.FileMergeDesc
 
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
 
setDryRun(boolean) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
setDummyOps(List<HashTableDummyOperator>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setDummyOps(List<HashTableDummyOperator>) - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
setDummyOpsMap(Map<Integer, DummyStoreOperator>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
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
 
setDummyTableScan(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setDumpFilePrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setDumpFilePrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setDynamicPartitioningKeys(List<String>) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Sets the list of dynamic partitioning keys used for outputting without specifying all the keys
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
 
setEmbeddedMode(boolean) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setEmptyResultSet(boolean) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setEnabled(boolean) - Method in class org.apache.hive.hcatalog.har.HarOutputCommitterPostProcessor
 
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
 
setEnforceSort(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setEntry(int, OrcProto.RowIndexEntry) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
setEntry(int, OrcProto.RowIndexEntry.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex.Builder
repeated .orc.proto.RowIndexEntry entry = 1;
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setEnvironment_context(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setEnvironment_contextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setEnvironmentContext(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setEnvironmentContext(EnvironmentContext) - Method in class org.apache.hadoop.hive.metastore.events.ListenerEvent
 
setEnvironmentContextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setError(String) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
setError(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setErrorCode(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setErrorCode(int) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setErrorCode(int) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setErrorCodeIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setErrorCodeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setErrorCodeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setErrorFile(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Currently unused.
setErrorHandler(ErrorHandler) - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
setErrorMessage(String) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setErrorMessage(String) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setErrorMessageIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setErrorMessageIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setErrorOnSrcEmpty(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
setErrorStream(PrintStream) - Method in class org.apache.hive.beeline.BeeLine
 
setErrRecordReaderClass(Class<? extends RecordReader>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setEscapeProcessing(boolean) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setEscapeProcessing(boolean) - Method in class org.apache.hive.jdbc.HiveStatement
 
setEval(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
setEventId(long) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
setEventId(long) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEventId(long) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setEventIdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
setEventIdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEvents(List<NotificationEvent>) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
setEventsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
setEventSourceColumnNameMap(Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setEventSourcePartKeyExprMap(Map<String, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setEventSourceTableDescMap(Map<String, List<TableDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setEventTime(int) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEventTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setEventTime(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
setEventTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEventType(String) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEventType(PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setEventType(PartitionEventType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setEventType(String) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setEventType(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
setEventTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setEventTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setEventTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setException(Throwable) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setExcludeQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setExclusive() - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the lock to be exclusive.
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
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setExit(boolean) - Method in class org.apache.hive.beeline.BeeLine
 
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
 
setExitValue(long) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setExpectedDirectory(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
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(byte[]) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
setExpr(ByteBuffer) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
setExpr(byte[]) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setExpr(ByteBuffer) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
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
 
setExprIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
setExprIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
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(List<DropPartitionsExpr>) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
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
 
setExtendedLiteral(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyBooleanObjectInspector
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setFailOnInit(boolean) - Method in class org.apache.hive.service.BreakableService
 
setFailOnStart(boolean) - Method in class org.apache.hive.service.BreakableService
 
setFailOnStop(boolean) - Method in class org.apache.hive.service.BreakableService
 
setFeedSubscribers(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setFetchDirection(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
setFetchDirection(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setFetchDirection(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
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
 
setFetchSize(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
setFetchSize(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setFetchSize(int) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setFetchSize(int) - Method in class org.apache.hive.jdbc.HiveQueryResultSet
 
setFetchSize(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
setFetchSource(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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
 
setFetchType(short) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setFetchTypeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setField(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
setField(String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Store a String field from the store.
setField0(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setField0IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setField1(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField1IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField2(String) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField2IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField3(List<InnerStruct>) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField3IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
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
 
setFieldInited(boolean[]) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setFieldNames(int, String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated string fieldNames = 3;
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFields(List<MFieldSchema>) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setFields(LazyObject[]) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setFieldSchemas(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldSchemasIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldsIntoOldStats(MTableColumnStatistics, MTableColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
setFieldsIntoOldStats(MPartitionColumnStatistics, MPartitionColumnStatistics) - Static method in class org.apache.hadoop.hive.metastore.StatObjectConverter
 
setFieldsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFieldValidator(IndexPredicateAnalyzer.FieldValidator) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
 
setFieldValue(AbortTxnRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
setFieldValue(AddDynamicPartitions._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setFieldValue(AddPartitionsRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setFieldValue(AddPartitionsResult._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
setFieldValue(AggrStats._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
setFieldValue(AlreadyExistsException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setFieldValue(BinaryColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setFieldValue(BooleanColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
setFieldValue(CheckLockRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
setFieldValue(ColumnStatistics._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
setFieldValue(ColumnStatisticsDesc._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setFieldValue(ColumnStatisticsObj._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setFieldValue(CommitTxnRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
setFieldValue(CompactionRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setFieldValue(ConfigValSecurityException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setFieldValue(CurrentNotificationEventId._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
setFieldValue(Database._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setFieldValue(Date._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
setFieldValue(DateColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setFieldValue(Decimal._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setFieldValue(DecimalColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setFieldValue(DoubleColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setFieldValue(DropPartitionsExpr._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
setFieldValue(DropPartitionsRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setFieldValue(DropPartitionsResult._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
setFieldValue(EnvironmentContext._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
setFieldValue(FieldSchema._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setFieldValue(FireEventRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setFieldValue(FireEventResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
setFieldValue(Function._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setFieldValue(GetOpenTxnsInfoResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
setFieldValue(GetOpenTxnsResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
setFieldValue(GetPrincipalsInRoleRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
setFieldValue(GetPrincipalsInRoleResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
setFieldValue(GetRoleGrantsForPrincipalRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
setFieldValue(GetRoleGrantsForPrincipalResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
setFieldValue(GrantRevokePrivilegeRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setFieldValue(GrantRevokePrivilegeResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
setFieldValue(GrantRevokeRoleRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setFieldValue(GrantRevokeRoleResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
setFieldValue(HeartbeatRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
setFieldValue(HeartbeatTxnRangeRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
setFieldValue(HeartbeatTxnRangeResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
setFieldValue(HiveObjectPrivilege._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setFieldValue(HiveObjectRef._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setFieldValue(Index._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setFieldValue(IndexAlreadyExistsException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setFieldValue(InsertEventRequestData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
setFieldValue(InvalidInputException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
setFieldValue(InvalidObjectException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setFieldValue(InvalidOperationException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setFieldValue(InvalidPartitionException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
setFieldValue(LockComponent._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setFieldValue(LockRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setFieldValue(LockResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
setFieldValue(LongColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setFieldValue(MetaException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setFieldValue(NoSuchLockException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
setFieldValue(NoSuchObjectException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setFieldValue(NoSuchTxnException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
setFieldValue(NotificationEvent._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setFieldValue(NotificationEventRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
setFieldValue(NotificationEventResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
setFieldValue(OpenTxnRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setFieldValue(OpenTxnsResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
setFieldValue(Order._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setFieldValue(Partition._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setFieldValue(PartitionListComposingSpec._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
setFieldValue(PartitionsByExprRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setFieldValue(PartitionsByExprResult._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
setFieldValue(PartitionSpec._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setFieldValue(PartitionSpecWithSharedSD._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
setFieldValue(PartitionsStatsRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setFieldValue(PartitionsStatsResult._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
setFieldValue(PartitionWithoutSD._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setFieldValue(PrincipalPrivilegeSet._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setFieldValue(PrivilegeBag._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setFieldValue(PrivilegeGrantInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setFieldValue(ResourceUri._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
setFieldValue(Role._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setFieldValue(RolePrincipalGrant._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setFieldValue(Schema._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldValue(SerDeInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setFieldValue(SetPartitionsStatsRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
setFieldValue(ShowCompactRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
setFieldValue(ShowCompactResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
setFieldValue(ShowCompactResponseElement._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setFieldValue(ShowLocksRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
setFieldValue(ShowLocksResponse._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
setFieldValue(ShowLocksResponseElement._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setFieldValue(SkewedInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setFieldValue(StorageDescriptor._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setFieldValue(StringColumnStatsData._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setFieldValue(Table._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setFieldValue(TableStatsRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
setFieldValue(TableStatsResult._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
setFieldValue(ThriftHiveMetastore.abort_txn_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
setFieldValue(ThriftHiveMetastore.abort_txn_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
setFieldValue(ThriftHiveMetastore.add_dynamic_partitions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
setFieldValue(ThriftHiveMetastore.add_dynamic_partitions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
setFieldValue(ThriftHiveMetastore.add_index_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setFieldValue(ThriftHiveMetastore.add_index_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setFieldValue(ThriftHiveMetastore.add_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setFieldValue(ThriftHiveMetastore.add_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setFieldValue(ThriftHiveMetastore.add_partition_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.add_partition_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.add_partitions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
setFieldValue(ThriftHiveMetastore.add_partitions_pspec_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
setFieldValue(ThriftHiveMetastore.add_partitions_pspec_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setFieldValue(ThriftHiveMetastore.add_partitions_req_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
setFieldValue(ThriftHiveMetastore.add_partitions_req_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setFieldValue(ThriftHiveMetastore.add_partitions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setFieldValue(ThriftHiveMetastore.alter_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setFieldValue(ThriftHiveMetastore.alter_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setFieldValue(ThriftHiveMetastore.alter_function_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setFieldValue(ThriftHiveMetastore.alter_function_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
setFieldValue(ThriftHiveMetastore.alter_index_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setFieldValue(ThriftHiveMetastore.alter_index_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setFieldValue(ThriftHiveMetastore.alter_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setFieldValue(ThriftHiveMetastore.alter_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setFieldValue(ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.alter_partitions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setFieldValue(ThriftHiveMetastore.alter_partitions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
setFieldValue(ThriftHiveMetastore.alter_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setFieldValue(ThriftHiveMetastore.alter_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setFieldValue(ThriftHiveMetastore.alter_table_with_cascade_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setFieldValue(ThriftHiveMetastore.alter_table_with_cascade_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
setFieldValue(ThriftHiveMetastore.alter_table_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.alter_table_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.append_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.append_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setFieldValue(ThriftHiveMetastore.append_partition_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.append_partition_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.cancel_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.cancel_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.check_lock_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
setFieldValue(ThriftHiveMetastore.check_lock_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setFieldValue(ThriftHiveMetastore.commit_txn_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
setFieldValue(ThriftHiveMetastore.commit_txn_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
setFieldValue(ThriftHiveMetastore.compact_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
setFieldValue(ThriftHiveMetastore.compact_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
setFieldValue(ThriftHiveMetastore.create_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setFieldValue(ThriftHiveMetastore.create_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setFieldValue(ThriftHiveMetastore.create_function_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
setFieldValue(ThriftHiveMetastore.create_function_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setFieldValue(ThriftHiveMetastore.create_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setFieldValue(ThriftHiveMetastore.create_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setFieldValue(ThriftHiveMetastore.create_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setFieldValue(ThriftHiveMetastore.create_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setFieldValue(ThriftHiveMetastore.create_table_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.create_table_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.create_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setFieldValue(ThriftHiveMetastore.create_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setFieldValue(ThriftHiveMetastore.delete_partition_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.delete_partition_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setFieldValue(ThriftHiveMetastore.delete_table_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.delete_table_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setFieldValue(ThriftHiveMetastore.drop_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setFieldValue(ThriftHiveMetastore.drop_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setFieldValue(ThriftHiveMetastore.drop_function_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
setFieldValue(ThriftHiveMetastore.drop_function_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
setFieldValue(ThriftHiveMetastore.drop_index_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setFieldValue(ThriftHiveMetastore.drop_index_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.drop_partitions_req_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
setFieldValue(ThriftHiveMetastore.drop_partitions_req_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setFieldValue(ThriftHiveMetastore.drop_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setFieldValue(ThriftHiveMetastore.drop_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setFieldValue(ThriftHiveMetastore.drop_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setFieldValue(ThriftHiveMetastore.drop_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setFieldValue(ThriftHiveMetastore.drop_table_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.drop_table_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.drop_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
setFieldValue(ThriftHiveMetastore.drop_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setFieldValue(ThriftHiveMetastore.exchange_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setFieldValue(ThriftHiveMetastore.exchange_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setFieldValue(ThriftHiveMetastore.fire_listener_event_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
setFieldValue(ThriftHiveMetastore.fire_listener_event_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
setFieldValue(ThriftHiveMetastore.get_aggr_stats_for_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
setFieldValue(ThriftHiveMetastore.get_aggr_stats_for_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setFieldValue(ThriftHiveMetastore.get_all_databases_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
setFieldValue(ThriftHiveMetastore.get_all_databases_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setFieldValue(ThriftHiveMetastore.get_all_tables_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setFieldValue(ThriftHiveMetastore.get_all_tables_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setFieldValue(ThriftHiveMetastore.get_config_value_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setFieldValue(ThriftHiveMetastore.get_config_value_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setFieldValue(ThriftHiveMetastore.get_current_notificationEventId_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
setFieldValue(ThriftHiveMetastore.get_current_notificationEventId_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
setFieldValue(ThriftHiveMetastore.get_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setFieldValue(ThriftHiveMetastore.get_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setFieldValue(ThriftHiveMetastore.get_databases_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
setFieldValue(ThriftHiveMetastore.get_databases_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.get_fields_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setFieldValue(ThriftHiveMetastore.get_fields_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setFieldValue(ThriftHiveMetastore.get_fields_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.get_fields_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.get_function_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
setFieldValue(ThriftHiveMetastore.get_function_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setFieldValue(ThriftHiveMetastore.get_functions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
setFieldValue(ThriftHiveMetastore.get_functions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
setFieldValue(ThriftHiveMetastore.get_index_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setFieldValue(ThriftHiveMetastore.get_index_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setFieldValue(ThriftHiveMetastore.get_index_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setFieldValue(ThriftHiveMetastore.get_index_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setFieldValue(ThriftHiveMetastore.get_indexes_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setFieldValue(ThriftHiveMetastore.get_indexes_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setFieldValue(ThriftHiveMetastore.get_next_notification_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
setFieldValue(ThriftHiveMetastore.get_next_notification_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
setFieldValue(ThriftHiveMetastore.get_open_txns_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
setFieldValue(ThriftHiveMetastore.get_open_txns_info_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
setFieldValue(ThriftHiveMetastore.get_open_txns_info_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
setFieldValue(ThriftHiveMetastore.get_open_txns_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
setFieldValue(ThriftHiveMetastore.get_part_specs_by_filter_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setFieldValue(ThriftHiveMetastore.get_part_specs_by_filter_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setFieldValue(ThriftHiveMetastore.get_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setFieldValue(ThriftHiveMetastore.get_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.get_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.get_partition_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.get_partition_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setFieldValue(ThriftHiveMetastore.get_partition_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setFieldValue(ThriftHiveMetastore.get_partition_names_ps_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setFieldValue(ThriftHiveMetastore.get_partition_names_ps_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setFieldValue(ThriftHiveMetastore.get_partition_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setFieldValue(ThriftHiveMetastore.get_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setFieldValue(ThriftHiveMetastore.get_partition_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partition_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_expr_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_expr_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_filter_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_filter_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_pspec_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_pspec_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_statistics_req_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_statistics_req_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_principals_in_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
setFieldValue(ThriftHiveMetastore.get_principals_in_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
setFieldValue(ThriftHiveMetastore.get_privilege_set_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setFieldValue(ThriftHiveMetastore.get_privilege_set_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setFieldValue(ThriftHiveMetastore.get_role_grants_for_principal_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
setFieldValue(ThriftHiveMetastore.get_role_grants_for_principal_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
setFieldValue(ThriftHiveMetastore.get_role_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
setFieldValue(ThriftHiveMetastore.get_role_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setFieldValue(ThriftHiveMetastore.get_schema_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setFieldValue(ThriftHiveMetastore.get_schema_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setFieldValue(ThriftHiveMetastore.get_schema_with_environment_context_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setFieldValue(ThriftHiveMetastore.get_schema_with_environment_context_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setFieldValue(ThriftHiveMetastore.get_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setFieldValue(ThriftHiveMetastore.get_table_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.get_table_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setFieldValue(ThriftHiveMetastore.get_table_names_by_filter_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setFieldValue(ThriftHiveMetastore.get_table_names_by_filter_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setFieldValue(ThriftHiveMetastore.get_table_objects_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
setFieldValue(ThriftHiveMetastore.get_table_objects_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setFieldValue(ThriftHiveMetastore.get_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setFieldValue(ThriftHiveMetastore.get_table_statistics_req_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
setFieldValue(ThriftHiveMetastore.get_table_statistics_req_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setFieldValue(ThriftHiveMetastore.get_tables_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setFieldValue(ThriftHiveMetastore.get_tables_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setFieldValue(ThriftHiveMetastore.get_type_all_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setFieldValue(ThriftHiveMetastore.get_type_all_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setFieldValue(ThriftHiveMetastore.get_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setFieldValue(ThriftHiveMetastore.get_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setFieldValue(ThriftHiveMetastore.getMetaConf_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
setFieldValue(ThriftHiveMetastore.getMetaConf_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
setFieldValue(ThriftHiveMetastore.grant_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setFieldValue(ThriftHiveMetastore.grant_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setFieldValue(ThriftHiveMetastore.grant_revoke_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
setFieldValue(ThriftHiveMetastore.grant_revoke_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
setFieldValue(ThriftHiveMetastore.grant_revoke_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
setFieldValue(ThriftHiveMetastore.grant_revoke_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
setFieldValue(ThriftHiveMetastore.grant_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setFieldValue(ThriftHiveMetastore.grant_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setFieldValue(ThriftHiveMetastore.heartbeat_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
setFieldValue(ThriftHiveMetastore.heartbeat_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setFieldValue(ThriftHiveMetastore.heartbeat_txn_range_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
setFieldValue(ThriftHiveMetastore.heartbeat_txn_range_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
setFieldValue(ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setFieldValue(ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setFieldValue(ThriftHiveMetastore.list_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setFieldValue(ThriftHiveMetastore.list_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setFieldValue(ThriftHiveMetastore.list_roles_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setFieldValue(ThriftHiveMetastore.list_roles_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setFieldValue(ThriftHiveMetastore.lock_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
setFieldValue(ThriftHiveMetastore.lock_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setFieldValue(ThriftHiveMetastore.markPartitionForEvent_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setFieldValue(ThriftHiveMetastore.markPartitionForEvent_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setFieldValue(ThriftHiveMetastore.open_txns_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
setFieldValue(ThriftHiveMetastore.open_txns_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
setFieldValue(ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
setFieldValue(ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
setFieldValue(ThriftHiveMetastore.partition_name_to_spec_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setFieldValue(ThriftHiveMetastore.partition_name_to_spec_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setFieldValue(ThriftHiveMetastore.partition_name_to_vals_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setFieldValue(ThriftHiveMetastore.partition_name_to_vals_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setFieldValue(ThriftHiveMetastore.rename_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setFieldValue(ThriftHiveMetastore.rename_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
setFieldValue(ThriftHiveMetastore.renew_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.renew_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.revoke_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
setFieldValue(ThriftHiveMetastore.revoke_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setFieldValue(ThriftHiveMetastore.revoke_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setFieldValue(ThriftHiveMetastore.revoke_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setFieldValue(ThriftHiveMetastore.set_aggr_stats_for_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
setFieldValue(ThriftHiveMetastore.set_aggr_stats_for_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setFieldValue(ThriftHiveMetastore.set_ugi_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
setFieldValue(ThriftHiveMetastore.set_ugi_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
setFieldValue(ThriftHiveMetastore.setMetaConf_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
setFieldValue(ThriftHiveMetastore.setMetaConf_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
setFieldValue(ThriftHiveMetastore.show_compact_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
setFieldValue(ThriftHiveMetastore.show_compact_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
setFieldValue(ThriftHiveMetastore.show_locks_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
setFieldValue(ThriftHiveMetastore.show_locks_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
setFieldValue(ThriftHiveMetastore.unlock_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
setFieldValue(ThriftHiveMetastore.unlock_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
setFieldValue(ThriftHiveMetastore.update_partition_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.update_partition_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setFieldValue(ThriftHiveMetastore.update_table_column_statistics_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
setFieldValue(ThriftHiveMetastore.update_table_column_statistics_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setFieldValue(TxnAbortedException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
setFieldValue(TxnInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setFieldValue(TxnOpenException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
setFieldValue(Type._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFieldValue(UnknownDBException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setFieldValue(UnknownPartitionException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
setFieldValue(UnknownTableException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setFieldValue(UnlockRequest._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
setFieldValue(Version._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setFieldValue(Adjacency._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setFieldValue(Graph._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setFieldValue(Operator._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setFieldValue(Query._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setFieldValue(QueryPlan._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setFieldValue(Stage._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setFieldValue(Task._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setFieldValue(InnerStruct._Fields, Object) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setFieldValue(ThriftTestObj._Fields, Object) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setFieldValue(Complex._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setFieldValue(IntString._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setFieldValue(MegaStruct._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setFieldValue(MiniStruct._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
setFieldValue(SetIntString._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
setFieldValue(HiveClusterStatus._Fields, Object) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setFieldValue(HiveServerException._Fields, Object) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setFieldValue(ThriftHive.clean_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
setFieldValue(ThriftHive.clean_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
setFieldValue(ThriftHive.execute_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setFieldValue(ThriftHive.execute_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setFieldValue(ThriftHive.fetchAll_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
setFieldValue(ThriftHive.fetchAll_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setFieldValue(ThriftHive.fetchN_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setFieldValue(ThriftHive.fetchN_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setFieldValue(ThriftHive.fetchOne_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
setFieldValue(ThriftHive.fetchOne_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setFieldValue(ThriftHive.getClusterStatus_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
setFieldValue(ThriftHive.getClusterStatus_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setFieldValue(ThriftHive.getQueryPlan_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
setFieldValue(ThriftHive.getQueryPlan_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setFieldValue(ThriftHive.getSchema_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
setFieldValue(ThriftHive.getSchema_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setFieldValue(ThriftHive.getThriftSchema_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
setFieldValue(ThriftHive.getThriftSchema_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setFieldValue(TArrayTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
setFieldValue(TBinaryColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setFieldValue(TBoolColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setFieldValue(TBoolValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
setFieldValue(TByteColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setFieldValue(TByteValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
setFieldValue(TCancelDelegationTokenReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
setFieldValue(TCancelDelegationTokenResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
setFieldValue(TCancelOperationReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
setFieldValue(TCancelOperationResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
setFieldValue(TCLIService.CancelDelegationToken_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
setFieldValue(TCLIService.CancelDelegationToken_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
setFieldValue(TCLIService.CancelOperation_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
setFieldValue(TCLIService.CancelOperation_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
setFieldValue(TCLIService.CloseOperation_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
setFieldValue(TCLIService.CloseOperation_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
setFieldValue(TCLIService.CloseSession_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
setFieldValue(TCLIService.CloseSession_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
setFieldValue(TCLIService.ExecuteStatement_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
setFieldValue(TCLIService.ExecuteStatement_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
setFieldValue(TCLIService.FetchResults_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
setFieldValue(TCLIService.FetchResults_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
setFieldValue(TCLIService.GetCatalogs_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
setFieldValue(TCLIService.GetCatalogs_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
setFieldValue(TCLIService.GetColumns_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
setFieldValue(TCLIService.GetColumns_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
setFieldValue(TCLIService.GetDelegationToken_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
setFieldValue(TCLIService.GetDelegationToken_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
setFieldValue(TCLIService.GetFunctions_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
setFieldValue(TCLIService.GetFunctions_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
setFieldValue(TCLIService.GetInfo_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
setFieldValue(TCLIService.GetInfo_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
setFieldValue(TCLIService.GetOperationStatus_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
setFieldValue(TCLIService.GetOperationStatus_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
setFieldValue(TCLIService.GetResultSetMetadata_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
setFieldValue(TCLIService.GetResultSetMetadata_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
setFieldValue(TCLIService.GetSchemas_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
setFieldValue(TCLIService.GetSchemas_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
setFieldValue(TCLIService.GetTables_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
setFieldValue(TCLIService.GetTables_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
setFieldValue(TCLIService.GetTableTypes_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
setFieldValue(TCLIService.GetTableTypes_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
setFieldValue(TCLIService.GetTypeInfo_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
setFieldValue(TCLIService.GetTypeInfo_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
setFieldValue(TCLIService.OpenSession_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
setFieldValue(TCLIService.OpenSession_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
setFieldValue(TCLIService.RenewDelegationToken_args._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
setFieldValue(TCLIService.RenewDelegationToken_result._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
setFieldValue(TCloseOperationReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
setFieldValue(TCloseOperationResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
setFieldValue(TCloseSessionReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
setFieldValue(TCloseSessionResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
setFieldValue(TColumnDesc._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setFieldValue(TDoubleColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setFieldValue(TDoubleValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
setFieldValue(TExecuteStatementReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setFieldValue(TExecuteStatementResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
setFieldValue(TFetchResultsReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setFieldValue(TFetchResultsResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setFieldValue(TGetCatalogsReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
setFieldValue(TGetCatalogsResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
setFieldValue(TGetColumnsReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setFieldValue(TGetColumnsResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
setFieldValue(TGetDelegationTokenReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setFieldValue(TGetDelegationTokenResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
setFieldValue(TGetFunctionsReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setFieldValue(TGetFunctionsResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
setFieldValue(TGetInfoReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
setFieldValue(TGetInfoResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
setFieldValue(TGetOperationStatusReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
setFieldValue(TGetOperationStatusResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setFieldValue(TGetResultSetMetadataReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
setFieldValue(TGetResultSetMetadataResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
setFieldValue(TGetSchemasReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setFieldValue(TGetSchemasResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
setFieldValue(TGetTablesReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setFieldValue(TGetTablesResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
setFieldValue(TGetTableTypesReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
setFieldValue(TGetTableTypesResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
setFieldValue(TGetTypeInfoReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
setFieldValue(TGetTypeInfoResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
setFieldValue(THandleIdentifier._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setFieldValue(TI16Column._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setFieldValue(TI16Value._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
setFieldValue(TI32Column._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setFieldValue(TI32Value._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
setFieldValue(TI64Column._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setFieldValue(TI64Value._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
setFieldValue(TMapTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
setFieldValue(TOpenSessionReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setFieldValue(TOpenSessionResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setFieldValue(TOperationHandle._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setFieldValue(TPrimitiveTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
setFieldValue(TRenewDelegationTokenReq._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
setFieldValue(TRenewDelegationTokenResp._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
setFieldValue(TRow._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TRow
 
setFieldValue(TRowSet._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setFieldValue(TSessionHandle._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
setFieldValue(TStatus._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setFieldValue(TStringColumn._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
setFieldValue(TStringValue._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
setFieldValue(TStructTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
setFieldValue(TTableSchema._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
setFieldValue(TTypeDesc._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
setFieldValue(TTypeQualifiers._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
setFieldValue(TUnionTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
setFieldValue(TUserDefinedTypeEntry._Fields, Object) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
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
 
setFilesAdded(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
setFilesAddedIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
setFileSchema(Schema) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
setFilter(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setFilter(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFilter(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setFilter(JobConf) - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
setFilter(String) - Method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Deprecated.
as of 0.13, slated for removal with 0.15 Use HCatInputFormat.setInput(org.apache.hadoop.conf.Configuration, String, String, String) instead, to specify a partition filter to directly initialize the input with.
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
 
setFilterIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setFilterIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFilterIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
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
 
setFilterObject(Serializable) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
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
 
setFilterWithSubQuery(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setFinalMapRed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setFirst(F) - Method in class org.apache.hadoop.hive.common.ObjectPair
 
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
 
setFlag(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
setFloat(String, HCatSchema, Float) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setFloat(String, float) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setFloat(int, float) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setFloat(int, float) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setFloatVar(Configuration, HiveConf.ConfVars, float) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setFloatVar(HiveConf.ConfVars, float) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setFnName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
setFoldedFromCol(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
setFoldedFromVal(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
setFollowedByGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setFooterLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 footerLength = 1;
setFooterLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 footerLength = 4;
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, LazyBinaryUtils.VInt) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
setFromBytes(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
setFromBytes(byte[], int, int, LazyBinaryUtils.VInt, LazyBinaryUtils.VLong) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
setFromBytes(byte[], int, int, LazyBinaryUtils.VInt) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
setFromOther(MapJoinTableContainer.ReusableGetAdaptor) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
Changes current rows to which adaptor is referring to the rows corresponding to the key that another adaptor has already deserialized via setFromVector/setFromRow.
setFromRow(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
Changes current rows to which adaptor is referring to the rows corresponding to the key represented by a row object, and fields and ois used to interpret it.
setFromVector(VectorHashKeyWrapper, VectorExpressionWriter[], VectorHashKeyWrapperBatch) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer.ReusableGetAdaptor
Changes current rows to which adaptor is referring to the rows corresponding to the key represented by a VHKW object, and writers and batch used to interpret it.
setFullFileStatus(Configuration, HadoopShims.HdfsFileStatus, FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
setFullFileStatus(Configuration, HadoopShims.HdfsFileStatus, FileSystem, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
setFullFileStatus(Configuration, HadoopShims.HdfsFileStatus, FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
For a given file, set a given file status.
setFullyReadColumns(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Deprecated.
for backwards compatibility with <= 0.12, use setReadAllColumns
setFunc(Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
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
 
setFuncIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
setFuncName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setFuncName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
setFuncName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
setFuncNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setFuncNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
setFuncNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
setFunction(PTFInvocationSpec.PartitionedTableFunctionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
setFunctionName(String) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setFunctionNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setFunctionNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setFunctionType(FunctionType) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setFunctionType(int) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setFunctionTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
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
 
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
 
setGenJoinKeys(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setGlobalLimitCtx(GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setGoOn(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setGrant(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrant_option(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrant_optionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantDesc(GrantDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGrantInfo(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setGrantInfoIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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.plan.RevokeDesc
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGrantOptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantOptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantOptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
setGrantorIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantorIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantorName(String) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantorNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantorPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantorPrincipalTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
setGrantorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setGrantorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantRevokeRoleDDL(GrantRevokeRoleDDL) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGrantTime(int) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGrantTime(int) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGrantTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setGroup(boolean) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
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
 
setGroupByOperators(List<GroupByOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setGroupDisplayName(String) - Method in class org.apache.hive.spark.counter.SparkCounterGroup
 
setGroupingSetPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupingSetsPresent(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupKeyObject(Object) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setGroupPrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setGroupPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setGroups(String[]) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setGuid(byte[]) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setGuid(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setGuidIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setHadoopSupportsSplittable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setHadoopVersion(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setHandled(boolean) - Method in class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
setHandler(HiveMetaStore.HMSHandler) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase.HiveProxy
 
setHandlerChain(List<HiveIOExceptionHandler>) - Method in class org.apache.hadoop.hive.io.HiveIOExceptionHandlerChain
set the exception handler chain
setHandleResult(boolean) - Method in class org.apache.hadoop.hive.io.HiveIOExceptionNextHandleResult
 
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.
setHarRequested(boolean) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Sets whether or not hadoop archiving has been requested for this job
setHasClusterBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasDistributeBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasDropPrivilege(boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider.DropPrivilegeExtractor
 
setHasDynamicPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
setHasDynamicPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setHasDynamicPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
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
 
setHashTableImplementationType(VectorMapJoinDesc.HashTableImplementationType) - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
setHashTableKeyType(VectorMapJoinDesc.HashTableKeyType) - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
setHashTableKind(VectorMapJoinDesc.HashTableKind) - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
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
 
setHasLateralViews(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasMapGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasMoreRows(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setHasMoreRowsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setHasNull(boolean) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional bool hasNull = 10;
setHasOrderBy(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setHasOrderBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasOuterOrderBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasPTF(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasResultSet(boolean) - Method in class org.apache.hive.service.cli.operation.Operation
 
setHasResultSet(boolean) - Method in class org.apache.hive.service.cli.OperationHandle
 
setHasResultSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setHasResultSetIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
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
 
setHasUnknownPartitions(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
setHasUnknownPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
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
 
setHeaderLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 headerLength = 1;
setHiddenVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setHighValue(Date) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setHighValue(Decimal) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setHighValue(double) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setHighValue(long) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setHighValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setHighValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setHighValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setHighValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setHints(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHiveAddedJars(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
setHiveAddedJars(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Set added jars path info to MetaStoreClient.
setHiveConf(HiveConf) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreThread
Set the Hive configuration for this thread.
setHiveConf(Configuration) - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
setHiveConf(Configuration) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setHiveConfDir(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setHiveConfs(Map<String, String>) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setHiveConfWhiteList(HiveConf) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.SettableConfigUpdater
 
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
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setHiveRootDirectory(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setHiveSiteLocation(URL) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setHiveTxnManager(HiveTxnManager) - Method in class org.apache.hadoop.hive.ql.Context
 
setHiveVariables(Map<String, String>) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
setHiveVariables(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setHiveVars(Map<String, String>) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setHoldability(int) - Method in class org.apache.hive.jdbc.HiveConnection
 
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
 
setHost(String) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setHostname(String) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setHostname(String) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setHostname(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setHostname(String) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setHostnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setHostnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setHostnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setHostnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setHybridHashJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setI16Val(TI16Column) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setI16Val(TI16Value) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setI32Val(TI32Column) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setI32Val(TI32Value) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setI32Value(int) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
setI64Val(TI64Column) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setI64Val(TI64Value) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
setId(long) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
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
 
setIdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setIds(HeartbeatRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
setIdsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
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
 
setIdx_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setIdx_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setIdxProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIfClass(String) - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setIfExistsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
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
 
setIfNotExistsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setIfPurge(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setIgnoreProtection(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setIgnoreProtection(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setIgnoreProtectionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setIncludeQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setIndex(LineageCtx.Index) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Sets the index for the lineage state.
setIndex_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setIndex_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setIndex_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setIndex_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setIndex_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setIndex_tableIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
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
 
setIndexHandlerClass(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexHandlerClass(String) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setIndexHandlerClassIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexInputFormat(String) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setIndexIntermediateFile(String) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setIndexKey(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setIndexKey(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
setIndexLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 indexLength = 2;
setIndexName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexName(String) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
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
 
setIndexNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTbl(String) - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
setIndexTypeHandlerClass(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setInfoMessages(List<String>) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setInfoMessagesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setInfoType(TGetInfoType) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
setInfoTypeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
setInfoValue(TGetInfoValue) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
setInfoValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
setInheritTableSpecs(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setInitScript(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setInListValues(HiveDecimal[]) - 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(HiveDecimal[]) - 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(HiveDecimal[]) - 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(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
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
 
setInput(Job, String, String) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Initializes the input with a null filter.
setInput(Job, String, String, String) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Initializes the input with a provided filter.
setInput(Configuration, String, String) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Initializes the input with a null filter.
setInput(Configuration, String, String, String) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Set inputs to use for the job.
setInputAliases(String[]) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
setInputAttributes(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Set hive input format, and input format file if necessary.
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.CastStringToIntervalDayTime
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.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
 
setInputColumnNames(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
setInputColumns(int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
setInputColumns(int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorElt
 
setInputContext(String, String, String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setInputContext(String, String, String) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
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.gen.VectorUDAFAvgDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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.VectorUDAFCountMerge
 
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.metastore.api.StorageDescriptor
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setInputFormat(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
setInputFormat(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
 
setInputFormat(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
setInputFormat(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
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
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
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
 
setInputFormatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setInputFormatSorted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setInputName(String) - Method in class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
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.orc.OrcFileKeyWrapper
 
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.merge.MergeFileWork
 
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.
setInputRefToCallMap(ImmutableMap<Integer, RexNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSort
 
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
 
setInputTableName(JobConf, String) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
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
 
setInsertData(InsertEventRequestData) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
setInsertToTable(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setInspector(OI) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
setInt(String, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setInt(int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setInt(int, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setInteger(String, HCatSchema, Integer) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setIntegerBitmask(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
setIntegerFlag(int) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
setInternal(MapJoinRowContainer, Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
setInternalList(List<String>) - Method in class org.apache.hadoop.hive.metastore.model.MStringList
 
setInternalName(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setInternalValueOi(LazyBinaryStructObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
setIntervalDayTimeTotalNanos(HiveIntervalDayTime, long) - Static method in class org.apache.hive.common.util.DateUtils
 
setIntStatistics(OrcProto.IntegerStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
setIntStatistics(OrcProto.IntegerStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.IntegerStatistics intStatistics = 2;
SetIntString - Class in org.apache.hadoop.hive.serde2.thrift.test
 
SetIntString() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
SetIntString(Set<IntString>, String) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
SetIntString(SetIntString) - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
Performs a deep copy on other.
SetIntString._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
setIntToTimestampInSeconds(boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TimestampConverter
 
setIntValue(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
setIntVar(Configuration, HiveConf.ConfVars, int) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setIntVar(HiveConf.ConfVars, int) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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
 
setIpAddress(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setIpAddress(TProtocol) - Method in class org.apache.hadoop.hive.metastore.TSetIpAddressProcessor
 
setIpAddress(Socket) - Method in class org.apache.hadoop.hive.metastore.TSetIpAddressProcessor
 
setIpAddress(TProtocol) - Method in class org.apache.hadoop.hive.metastore.TUGIBasedProcessor
 
setIpAddress(String) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
setIpAddress(String) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setIpAddress(TProtocol) - Method in class org.apache.hive.service.auth.TSetIpAddressProcessor
 
setIpAddress(String) - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
setIpAddress(String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
setIpAddress(String) - Static method in class org.apache.hive.service.cli.session.SessionManager
 
setIsAlterViewAs(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setIsAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setIsBigTableWork(boolean) - Method in class org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator
 
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
 
setIsHiveServerQuery(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setIsIncompatFile(boolean) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
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
 
setIsReduce(boolean) - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
setIsSamplingPred(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setIsSilent(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setIsTblLevel(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setIsTblLevelIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setIsVerbose(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setItems(TreeMap<HWIAuth, Set<HWISessionItem>>) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setJc(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setJdbcDriver(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setJdbcUriString(String) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setJdbcUrl(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
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
 
setJobLauncherRpcAddress(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
setJobLauncherRpcAddress(Configuration, String) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
setJobLauncherRpcAddress(Configuration, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
All updates to jobtracker/resource manager rpc address in the configuration should be done through this shim
setJobLauncherRpcAddress(Configuration, String) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure
 
setJobProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setJoinAlgorithm(HiveCostModel.JoinAlgorithm) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
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
 
setJoinCost(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin
 
setJoinExpr(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setJoinExpressions(ExprNodeDesc[]) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
 
setJoinKeys(ImmutableList<RexNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortExchange
 
setJoinOps(Set<JoinOperator>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setJoinResult(JoinUtil.JoinResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
Set the current join result.
setJoinSrc(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinType(JoinType) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setKey(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
setKey(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
setKey(Object) - Method in class org.apache.hadoop.hive.shims.CombineHiveKey
 
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
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
 
setKeyId(int) - Method in class org.apache.hadoop.hive.metastore.model.MMasterKey
 
setKeyIndex(int) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
setKeyIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
setKeyIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
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
 
setKeyObjects(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
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
 
setKeyTypePtr(int) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
setKeyTypePtrIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
setKeyValue(Writable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
setKeyValue(Writable, Writable) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.KeyValueHelper
 
setKind(OrcProto.ColumnEncoding.Kind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Builder
optional .orc.proto.ColumnEncoding.Kind kind = 1;
setKind(OrcProto.Stream.Kind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional .orc.proto.Stream.Kind kind = 1;
setKind(OrcProto.Type.Kind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional .orc.proto.Type.Kind kind = 1;
setLang(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setLastAnalyzed(long) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setLastAnalyzed(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setLastAnalyzed(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setLastAnalyzedIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setLastCommand(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setLastEvent(long) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
setLastEventIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
setLastheartbeat(long) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setLastheartbeatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setLastInputPath(Path) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setLastReduceLimitDesc(LimitDesc) - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
setLastStripeInFile(boolean) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
setLayout(Layout) - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
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(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
setLeft(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
setLeft(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
setLeft(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
setLeft(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
setLeft(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
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.
setLeftAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setLeftAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setLeftInputJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setLeftValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
setLeftValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
setLeftValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
setLeftValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
setLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
setLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Builder
optional uint64 length = 3;
setLength(int) - Method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
setLenValue(long) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
setLevel(LockLevel) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setLevelIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
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
 
setLint(List<Integer>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintString(List<IntString>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setList(String, HCatSchema, List<?>) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setListBucketingAlterTableConcatenate(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
setListBucketingCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
setListBucketingCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setListBucketingDepth(int) - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
setListElementTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
For java serialization use only.
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
 
setLoadHiveServer2Config(boolean) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setLoadMetastoreConfig(boolean) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
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
 
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.metastore.api.StorageDescriptor
 
setLocation(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setLocation(String) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
setLocation(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
setLocationIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setLocationUriIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setLockDatabaseDesc(LockDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setLockid(long) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
setLockid(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
setLockid(long) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
setLockid(long) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setLockid(long) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
setLockidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
setLockidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
setLockidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
setLockidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setLockidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
setLocks(List<ShowLocksResponseElement>) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
setLocksIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
setLockTblDesc(LockTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setLogDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setLogFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setLogical(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setLoginTimeout(int) - Method in class org.apache.hive.jdbc.HiveDataSource
 
setLogWriter(PrintWriter) - Method in class org.apache.hive.jdbc.HiveDataSource
 
setLong(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
setLong(String, HCatSchema, Long) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setLong(String, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setLong(int, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setLong(int, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setLongField(String, long) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Store a long field.
setLongHighValue(Long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setLongHighValue(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setLongLowValue(Long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setLongLowValue(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setLongStats(LongColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setLongStats(Long, Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setLongStats(Long, Long, Long, Long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
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
 
setLongValue(long) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
setLongVar(Configuration, HiveConf.ConfVars, long) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setLongVar(HiveConf.ConfVars, long) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setLowValue(Date) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setLowValue(Decimal) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setLowValue(double) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setLowValue(long) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setLowValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setLowValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setLowValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setLowValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setLString(List<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLString(List<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
setLStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setMacroName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setMagic(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
setMagicBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional string magic = 8000;
setMap(String, HCatSchema, Map<?, ?>) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setMapAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setMapAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMapCurrCtx(LinkedHashMap<Operator<? extends OperatorDesc>, GenMRProcContext.GenMapRedCtx>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setMapEntry(TMapTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setMapFunction(HiveMapFunction) - Method in class org.apache.hadoop.hive.ql.exec.spark.MapTran
 
setMapGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setMapJoinBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setMapJoinKey(MapJoinTableContainer.ReusableGetAdaptor, Object, byte) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
setMapJoinKey(MapJoinTableContainer.ReusableGetAdaptor, Object, byte) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
setMapJoinOps(Set<MapJoinOperator>) - 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
 
setMapKeyTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
For java serialization use only.
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
 
setMapRedLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setMapRedStats(Map<String, MapRedStats>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
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
 
setMapTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMapTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMapValueTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
For java serialization use only.
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
 
setMasterKey(String) - Method in class org.apache.hadoop.hive.metastore.model.MMasterKey
 
setMax(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
setMax_indexes(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setMax_indexes(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setMax_indexesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setMax_indexesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setMax_parts(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setMax_parts(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setMax_tables(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setMax_tablesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
setMaxColLen(long) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setMaxColLen(long) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setMaxColLen(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setMaxColLen(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setMaxColLenIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setMaxColLenIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setMaxEvents(int) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
setMaxEventsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
setMaxFieldSize(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setMaxFieldSize(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
setMaximum(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 maximum = 2;
setMaximum(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
setMaximum(double) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double maximum = 2;
setMaximum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 maximum = 2;
setMaximum(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
setMaximum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 maximum = 2;
setMaximumBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string maximum = 2;
setMaximumBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string maximum = 2;
setMaximumDynamicPartitions(int) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
Set maximum number of allowable dynamic partitions
setMaximumLength(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 maximumLength = 4;
setMaxIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToCharViaLongToChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToVarCharViaLongToVarChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToVarChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToVarChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToVarChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToChar
 
setMaxLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToVarChar
 
setMaxLength(int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.TruncStringOutput
 
setMaxMapTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxMapTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxPartitionsPerNode(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setMaxParts(short) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setMaxPartsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setMaxReduceTasks(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setMaxReduceTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxReduceTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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.
setMaxRows(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setMaxRows(int) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setMaxRows(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
setMaxRows(long) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setMaxRowsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
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
 
setMergeJoinOperator(CommonMergeJoinOperator) - Method in class org.apache.hadoop.hive.ql.plan.MergeJoinWork
 
setMergeWork(JobConf, MergeJoinWork, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
setMessage(String) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setMessage(String) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setMessage(String) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
setMessageIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setMetaConf(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.setMetaConf_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
setMetaConf(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.setMetaConf_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
setMetaConf(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
setMetaConf(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
setMetaConf(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setMetaConf(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
setMetaConf(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
set meta variable which is open to end users
setMetaConf(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
setMetadata(int, OrcProto.UserMetadataItem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
setMetadata(int, OrcProto.UserMetadataItem.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.UserMetadataItem metadata = 5;
setMetadata(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
setMetadata(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedConverterParent
 
setMetadataLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint64 metadataLength = 5;
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.MetaStoreAuthzAPIAuthorizerEmbedOnly
 
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.
setMetaStoreSchemaVersion(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
setMetaStoreSchemaVersion(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
setMin(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
setMinimum(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics.Builder
optional sint32 minimum = 1;
setMinimum(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
setMinimum(double) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double minimum = 1;
setMinimum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 minimum = 1;
setMinimum(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
setMinimum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics.Builder
optional sint64 minimum = 1;
setMinimumBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string minimum = 1;
setMinimumBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional string minimum = 1;
setMinIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
setMinMaxEnabled(boolean) - Method in class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
setMinReduceTasks(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
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
 
setMockInstance(JobConf, String) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
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
 
setModifiableWhiteListRegex(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
Set white list of parameters that are allowed to be modified
setModifiedRowCount(double) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setModifiedRowCountIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setMRShuffle() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
setMsckDesc(MsckDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setMStringString(Map<String, String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setMStringStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setMultiDestQuery(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
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
 
setMy_16bit_int(short) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_16bit_intIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_32bit_int(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_32bit_intIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_64bit_int(long) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_64bit_intIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_binary(byte[]) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_binary(ByteBuffer) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_binaryIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_bool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_boolIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_byte(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_byteIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_double(double) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_doubleIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum(MyEnum) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
setMy_enum_string_map(Map<MyEnum, String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_string_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_stringlist_map(Map<MyEnum, List<String>>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_stringlist_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_struct_map(Map<MyEnum, MiniStruct>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_struct_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_structlist_map(Map<MyEnum, List<MiniStruct>>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enum_structlist_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enumIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
setMy_enumlist(List<MyEnum>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enumlistIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enumset(Set<MyEnum>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_enumsetIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_string(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_string(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
setMy_string_enum_map(Map<String, MyEnum>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_string_enum_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_string_string_map(Map<String, String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_string_string_mapIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_stringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_stringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
setMy_stringlist(List<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_stringlistIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_stringset(Set<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_stringsetIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_structlist(List<MiniStruct>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_structlistIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_structset(Set<MiniStruct>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMy_structsetIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
setMyint(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setMyintIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setMyString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setMyStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setName(String) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setName(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
setName(String) - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
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
 
setName(String) - Method in class org.apache.hadoop.hive.shims.HiveEventCounter
 
setNameBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional string name = 1;
setNamed(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
setNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setNamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
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
 
setNameToTypePtr(Map<String, Integer>) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
setNameToTypePtr(Map<String, Integer>) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
setNameToTypePtrIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
setNameToTypePtrIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
setNCharacterStream(String, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNClob(String, NClob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(String, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(int, NClob) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(int, Reader) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNClob(int, NClob) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNClob(int, Reader) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNeededColumnIDs(List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setNeededColumnIDs(List<Integer>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setNeededColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setNeededColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setNeedLock(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setNeedLockMgr(boolean) - Method in class org.apache.hadoop.hive.ql.Context
 
setNeedResult(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setNeedResult(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setNeedResultIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setNeedResultIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setNeedsTagging(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setNetworkTimeout(Executor, int) - Method in class org.apache.hive.jdbc.HiveConnection
 
setNew_idx(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setNew_idxIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setNew_index(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setNew_indexIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setNew_parts(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
setNew_parts(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
setNew_parts(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setNew_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
setNew_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
setNew_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setNew_tbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setNew_tbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setNew_tbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setNew_tblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setNew_tblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setNew_tblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
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
 
setNewFunc(Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
setNewFuncIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
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
 
setNextEventId(long) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationNextId
 
setNextSpillPartition(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
setNode(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setNodeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setNodeType(NodeType) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setNodeTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
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.
setNoop(boolean) - Method in class org.apache.hadoop.hive.ql.parse.ReplicationSpec
 
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
 
setNoScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
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
 
setNosuch(Set<Long>) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
setNosuchIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
setNotifiedTime(long) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setNString(String, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNString(int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNString(int, String) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNull() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
setNull() - Method in interface org.apache.hadoop.hive.serde2.lazy.LazyObjectBase
called for null binary, hbase columns, for example
setNull() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryObject
 
setNull(String, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNull(String, int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNull(int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNull(int, int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setNull(int, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setNull(int, int, String) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
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.
setNullDataValue() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Vectorized execution uses the smallest possible positive non-zero value to prevent possible later zero-divide exceptions.
setNullDataValue(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
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
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setNulls(byte[]) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
setNulls(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
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
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setNullsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
setNum_txns(int) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setNum_txnsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
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
 
setNumberOfPartitions(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
 
setNumberOfRows(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint64 numberOfRows = 6;
setNumberOfRows(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 numberOfRows = 5;
setNumberOfValues(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional uint64 numberOfValues = 1;
setNumBuckets(int) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setNumBucketsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setNumDVs(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setNumDVsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setNumDVsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setNumDVsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setNumDVsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setNumDVsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setNumerator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the numerator.
setNumFalses(long) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
setNumFalses(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setNumFalses(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setNumFalses(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setNumFalsesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
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
 
setNumHashFunctions(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter.Builder
optional uint32 numHashFunctions = 1;
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.metastore.api.BinaryColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
setNumNullsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
setNumPartitions(int) - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
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
 
setNumRows(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
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.metastore.api.BooleanColumnStatsData
 
setNumTrues(long) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setNumTrues(long) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setNumTrues(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setNumTruesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
setO1(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
setO1(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setO1(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO1(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setO1(ConfigValSecurityException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setO1(NoSuchLockException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setO1(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
setO1(NoSuchLockException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO2(TxnAbortedException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO2(TxnAbortedException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO2(TxnAbortedException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO2(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO2(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO2(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO2(NoSuchTxnException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO2(TxnAbortedException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO2(TxnOpenException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO3(NoSuchLockException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO3(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO3(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
setO3(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO3(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO3(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO3(TxnAbortedException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO3(UnknownDBException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO4(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO4(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO4(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO4(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO4(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO4(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO4(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO4(InvalidInputException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setO5(UnknownPartitionException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO5(UnknownPartitionException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO5IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO5IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO6(InvalidPartitionException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO6(InvalidPartitionException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setO6IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setO6IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
setObj(HiveLockObject) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
setObject(String) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
setObject(String, Object) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(String, Object, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(String, Object, int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(int, Object) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(int, Object, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(int, Object, int, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setObject(int, Object) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setObject(int, Object, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setObject(int, Object, int, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setObjectinspector(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setObjectName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectType(HiveObjectType) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectTypePtr(int) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
setObjectTypePtrIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
setOffset(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation.Builder
optional uint64 offset = 1;
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
 
setOneBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRowSameBatch
 
setOneBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRowSameBatch
 
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
 
setOpen_txns(List<TxnInfo>) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
setOpen_txns(Set<Long>) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
setOpen_txnsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
setOpen_txnsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
setOperation(RoleDDLDesc.RoleOperation) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setOperationException(HiveSQLException) - Method in class org.apache.hive.service.cli.operation.Operation
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
setOperationHandle(TOperationHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
setOperationHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
setOperationId(String) - Method in class org.apache.hadoop.hive.ql.Driver
Set the HS2 operation handle's guid string
setOperationId(THandleIdentifier) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setOperationIdIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setOperationLog(OperationLog) - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
setOperationLogSessionDir(File) - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Set the session dir, which is the parent dir of operation logs
setOperationLogSessionDir(File) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
setOperationManager(OperationManager) - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Set operation manager for the session
setOperationManager(OperationManager) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
setOperationState(TOperationState) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setOperationStateIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setOperationTimeout(long) - Method in class org.apache.hive.service.cli.operation.Operation
 
setOperationType(TOperationType) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setOperationTypeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
setOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setOperator(boolean) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setOperatorAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorGraph(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorGraphIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorId(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOperatorId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorList(List<Operator>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorType(OperatorType) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOpPartToSkewedPruner(HashMap<TableScanOperator, Map<String, ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setOpSelectStatement(CommonTree, boolean) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
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
 
setOrderIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setOrderSpec(PTFInvocationSpec.OrderSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
setOrientation(TFetchOrientation) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
setOrientationIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
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
 
setOrigTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setOrigTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setOrigTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
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
 
setOuterQueryLimit(int) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setOutput(ByteStream.Output) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
setOutput(ByteStream.Output) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
setOutput(Job, OutputJobInfo) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
 
setOutput(Configuration, Credentials, OutputJobInfo) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
Set the information about the output to write for the job.
setOutputAppend(ByteStream.Output) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
setOutputAppend(ByteStream.Output) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
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.CastStringToIntervalDayTime
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToIntervalYearMonth
 
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.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.gen.CastDateToBooleanViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToBooleanViaDoubleToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastDoubleToTimestampViaDoubleToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToBooleanViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastLongToTimestampViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastMillisecondsLongToTimestampViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToBooleanViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToDoubleViaLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.CastTimestampToLongViaLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalDayTimeScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColAddDecimalColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColMultiplyDecimalColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DecimalColSubtractDecimalColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColUnaryMinus
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncAbsLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncACosLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncASinLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncATanLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilDoubleToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCeilLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncCosLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncDegreesLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncExpLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorDoubleToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncFloorLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLnLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10DoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog10LongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2DoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncLog2LongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRadiansLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncRoundDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSignLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSinLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncSqrtLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FuncTanLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleColumnLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprDoubleScalarLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongColumnLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IfExprLongScalarLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColUnaryMinus
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.StringGroupColConcatStringScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
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.StringScalarConcatStringGroupCol
 
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.VectorElt
 
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.merge.MergeFileWork
 
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
 
setOutputDirectory(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setOutputDirectory(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
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.metastore.api.StorageDescriptor
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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 OutputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
setOutputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
setOutputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
setOutputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
setOutputPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.FileMergeDesc
 
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
 
setOutputSchema(Job, HCatSchema) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseInputFormat
Set the schema for the HCatRecord data returned by HCatInputFormat.
setOutputSchema(HCatSchema) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
setOutputShape(ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
setOutputStream(PrintStream) - Method in class org.apache.hive.beeline.BeeLine
 
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(Path, String, String) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
setOwner(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setOwner(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setOwner(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOwner(String) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setOwnerIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setOwnerIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setOwnerNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setOwnerNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setOwnerNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setOwnerPrincipal(PrincipalDesc) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setOwnerType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setOwnerType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setOwnerType(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setOwnerType(String) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setOwnerTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setOwnerTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setP(Partition) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setParameterCompleters(Completer[]) - Method in class org.apache.hive.beeline.AbstractCommandHandler
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy.Iterator
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy.Iterator
 
setParameters(Map<String, String>) - Method in interface org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.PartitionIterator
Setter for Partition parameters.
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy.SimplePartitionWrapperIterator
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy.Iterator
 
setParameters(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setParamters(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setParent(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
Set parent job of this job
setParentDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setParentKeyCount(Map<Integer, Long>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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
 
setParsed(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
 
setParsed(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setPart_vals(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setPart_vals(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setPartArchiveLevel(int) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
setPartArchiveLevelIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
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
 
setPartDetails(OutputJobInfo, HCatSchema, Map<String, String>) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatBaseOutputFormat
 
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
 
setPartialScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setPartition(MPartition) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPartition(MPartition) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setPartition(MPartition) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
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
 
setPartitionColumnStatistics(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
setPartitionColumnStatistics(SetPartitionsStatsRequest) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
setPartitionColumnStatistics(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
setPartitionDescMap(Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>) - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
setPartitionFilter(Expression) - Method in class org.apache.hive.hcatalog.pig.HCatLoader
 
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
 
setPartitionKeys(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPartitionKeys(List<MFieldSchema>) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setPartitionKeysIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPartitionKeyValues(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatPartition
Setter for partition key-values.
setPartitionList(PartitionListComposingSpec) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setPartitionListIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setPartitionname(String) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setPartitionname(String) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setPartitionname(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the partition name.
setPartitionName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
setPartitionnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setPartitionnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setPartitionnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setPartitionnames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setPartitionnamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setPartitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
setPartitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
setPartitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
setPartitions(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
setPartitions(List<PartitionWithoutSD>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
setPartitions(PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpPartitionWalkerCtx
Set partitions.
setPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
setPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
setPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
setPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
setPartitionsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
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.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setPartitionSpecs(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
setPartitionSpecsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
SetPartitionsStatsRequest - Class in org.apache.hadoop.hive.metastore.api
 
SetPartitionsStatsRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
SetPartitionsStatsRequest(List<ColumnStatistics>) - Constructor for class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
SetPartitionsStatsRequest(SetPartitionsStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
Performs a deep copy on other.
SetPartitionsStatsRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
setPartitionVals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setPartitionValsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setPartitionValues(Map<String, String>) - Method in class org.apache.hive.hcatalog.mapreduce.PartInfo
Sets the partition values.
setPartKey(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
setPartKeySpec(FieldSchema) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
setPartName(String) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setPartname(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setPartName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
setPartNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setPartnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setPartNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setPartNamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setPartParams(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setParts(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setParts(RequestPartsSpec) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setPartsFound(long) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
setPartsFoundIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
setPartsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setPartsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
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
 
setPartStats(Map<String, List<ColumnStatisticsObj>>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
setPartStatsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
setPartValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setPartValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setPassWord(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
setPassword(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setPassword(String) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setPasswordIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
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.metastore.api.ThriftHiveMetastore.get_databases_args
 
setPattern(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
setPattern(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
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
 
setPatternIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
setPatternIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
setPatternIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setPctx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
setPercent(Double) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setPercentComplete(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
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
 
setPoolable(boolean) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setPoolable(boolean) - Method in class org.apache.hive.jdbc.HiveStatement
 
setPort(int) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
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
 
setPosition(int) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setPositionIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setPositions(int, long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
repeated uint64 positions = 1 [packed = true];
setPositive(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setPosOfDynPartCols(List<Integer>) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
setPosOfPartCols(List<Integer>) - Method in class org.apache.hive.hcatalog.mapreduce.OutputJobInfo
 
setPosToAliasMap(Map<Integer, Set<String>>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
setPosToAliasMap(Map<Integer, Set<String>>) - Method in class org.apache.hadoop.hive.ql.plan.SparkBucketMapJoinContext
 
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
 
setPrecision(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 precision = 5;
setPrecision(int) - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
setPrecision(Integer) - Method in class org.apache.hive.service.cli.TypeQualifiers
 
setPredicate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setPreserved(boolean) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setPreserved(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setPretty(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPrimaryKey(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setPrimitiveCompare(PrimitiveComparison) - Method in interface org.apache.hadoop.hive.accumulo.predicate.compare.CompareOp
Sets the PrimitiveComparison for this CompareOp
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Equal
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThan
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.GreaterThanOrEqual
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThan
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.LessThanOrEqual
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.Like
 
setPrimitiveCompare(PrimitiveComparison) - Method in class org.apache.hadoop.hive.accumulo.predicate.compare.NotEqual
 
setPrimitiveEntry(TPrimitiveTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
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
 
setPrincipalGrants(List<RolePrincipalGrant>) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
setPrincipalGrants(List<RolePrincipalGrant>) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
setPrincipalGrantsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
setPrincipalGrantsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setPrincipalNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setPrincipalNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
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.metastore.api.GrantRevokeRoleRequest
 
setPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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
 
setPrincipalTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setPrincipalTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setPriv(PrivilegeType) - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setPrivilege(Privilege) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
setPrivilegeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setPrivileges(List<HiveObjectPrivilege>) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
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
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
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(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
setProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setProperties(Properties) - Method in class org.apache.hive.hcatalog.mapreduce.HCatInputFormat
Set properties for the input format.
setProperties(Properties) - Method in class org.apache.hive.hcatalog.mapreduce.StorerInfo
 
setPropertiesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
setPropertiesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setProperty(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
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
 
setProxySession(HiveSession) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
setProxyUserName(String) - Static method in class org.apache.hive.service.cli.session.SessionManager
 
setPrunedPartitionList(PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
setPrunedPartitions(Map<String, PrunedPartitionList>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setPTFReduceSink(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
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
 
setQBJoinTreeProps(JoinDesc) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setQBJoinTreeProps(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setQBParseInfo(QBParseInfo) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setQFileDirectory(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setQFileName(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setQualifiers(Map<String, TTypeQualifierValue>) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
setQualifiersIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
setQueries(List<Query>) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setQueriesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setQuery(Query) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQuery(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setQuery(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setQueryAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryDef(PTFDesc) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
setQueryDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryFileRegex(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryHasGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
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
 
setQueryIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
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
 
setQueryRegex(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
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
 
setQueryTimeout(Statement, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setQueryTimeout(int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setQueryTimeout(int) - Method in class org.apache.hive.jdbc.HiveStatement
 
setQueryType(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
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
 
setRange(Number, Number) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setRange(ColStatistics.Range) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setRanges(JobConf, Collection<Range>) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
setRankLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
setRankLimitFunction(int) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
setRawDataSize(long) - Method in class org.apache.hadoop.hive.serde2.SerDeStats
Set the raw data size
setRawInputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
setRawInputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
setRawInputShape(ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setReadAllColumns(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Sets the READ_ALL_COLUMNS flag and removes any previously set column ids.
setReadColumnIDs(Configuration, List<Integer>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Deprecated.
for backwards compatibility with <= 0.12, use setReadAllColumns and appendReadColumns
setReaderAtSplit(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setReaderSchema(Schema) - Method in class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
Set the reader schema for the AvroLazyObjectInspector to the given schema
setReadOnly(boolean) - Method in class org.apache.hive.jdbc.HiveConnection
 
setReadPoint(long) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
setReadPoint(long, WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
setRecord(GenericRecord) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
setRecordIdentifier(RecordIdentifier) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
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
 
setRecordReaderID(UID) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
setRecordSources(RecordSource[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
setReduceFunction(HiveReduceFunction) - Method in class org.apache.hadoop.hive.ql.exec.spark.ReduceTran
 
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
 
setReducerTraits(EnumSet<ReduceSinkDesc.ReducerTraits>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setReduceSinkOperatorsAddedByEnforceBucketingSorting(List<ReduceSinkOperator>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setReduceTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setReduceTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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.
setRef(int, Ref) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setRef(int, Ref) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setReferencedColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setReferencedColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setReferencedColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setRejectedJoinOps(Set<JoinOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setRelativePath(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setRelativePathIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setReloadFunctionDesc(ReloadFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setRemovedReduceSinkBucketSort(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setRenamePartitionDesc(RenamePartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRenewer(String) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setRenewer_kerberos_principal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setRenewer_kerberos_principal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setRenewerIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setRepairPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setRepeatingColumn(VectorizedRowBatch, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Iterates thru all the column vectors and sets repeating to specified column.
setReplace(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setReplaceMode(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setReplaceMode(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setReplication(Path, short) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setReq(DropPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
setReq(PartitionsByExprRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
setReq(TCancelDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
setReq(TCancelOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
setReq(TCloseOperationReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
setReq(TCloseSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
setReq(TExecuteStatementReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
setReq(TFetchResultsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
setReq(TGetCatalogsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
setReq(TGetColumnsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
setReq(TGetDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
setReq(TGetFunctionsReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
setReq(TGetInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
setReq(TGetOperationStatusReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
setReq(TGetResultSetMetadataReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
setReq(TGetSchemasReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
setReq(TGetTablesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
setReq(TGetTableTypesReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
setReq(TGetTypeInfoReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
setReq(TOpenSessionReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
setReq(TRenewDelegationTokenReq) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
setReqIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
setReqIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
setReqIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
setRequest(AddPartitionsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
setRequest(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
setRequest(PartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
setRequest(GetPrincipalsInRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
setRequest(GetRoleGrantsForPrincipalRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
setRequest(TableStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
setRequest(GrantRevokePrivilegeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
setRequest(GrantRevokeRoleRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
setRequest(SetPartitionsStatsRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
setRequestIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
setRequestType(GrantRevokeType) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setRequestType(GrantRevokeType) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setRequestTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setRequestTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setRequiredCounterPrefix(Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.SparkWork
 
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(Path) - Method in class org.apache.hadoop.hive.ql.plan.ShowConfDesc
 
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
 
setResourceType(ResourceType) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
setResourceType(int) - Method in class org.apache.hadoop.hive.metastore.model.MResourceUri
 
setResourceTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
setResourceUris(List<ResourceUri>) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setResourceUris(List<MResourceUri>) - Method in class org.apache.hadoop.hive.metastore.model.MFunction
 
setResourceUrisIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
setResult(Result) - Method in class org.apache.hadoop.hive.hbase.ResultWritable
 
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
 
setResultBucketMaxSize(int) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
sets the value for resultBucketMaxSize.
setResultExprInfo(MatchPath.ResultExprInfo) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath
 
setResultExprNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExprInfo
 
setResultExprNodes(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExprInfo
 
setResultFile(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setResults(TRowSet) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setResultsDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setResultsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
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.metastore.api.Table
 
setRetention(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setRetention(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setRetentionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.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
 
setRevokeGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setRevokeGrantOptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnBetween
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterCharColumnNotBetween
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnBetween
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringColumnNotBetween
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnBetween
 
setRight(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterVarCharColumnNotBetween
 
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
 
setRightAliases(String[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setRightValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnBetween
 
setRightValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColumnNotBetween
 
setRightValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnBetween
 
setRightValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColumnNotBetween
 
setRole(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setRole(MRole) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setRoleDDLDesc(RoleDDLDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRoleIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setRoleName(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setRoleNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
setRoleNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
setRoleNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setRoleNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
setRoleOwnerName(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setRolePrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setRolePrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setRoles(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setRootLocation(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
setRootLocation(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
setRootLocation(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Setter for the common root-location for all partitions in the PartitionSet.
setRootLocation(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
setRootLocation(String) - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec
Setter for the "root" location of the HCatPartitionSpec.
setRootOperators(Deque<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
setRootPath(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setRootPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setRootPathIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setRoots(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setRootsIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
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
 
setRowCount(long) - Method in class org.apache.hadoop.hive.serde2.SerDeStats
Set the row count
setRowId(String) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
setRowId(long) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
setRowId(String, RowId) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setRowId(int, RowId) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setRowId(int, RowId) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setRowIndexStride(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
setRowIndexStride(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
optional uint32 rowIndexStride = 8;
setRowLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setRowResolver(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
setRows(List<TRow>) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setRowSchema(RowSchema) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setRowsIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setRowSkewedIndex(List<SkewedColumnPositionPair>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setRqst(AbortTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
setRqst(AddDynamicPartitions) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
setRqst(CheckLockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
setRqst(CommitTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
setRqst(CompactionRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
setRqst(FireEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
setRqst(NotificationEventRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
setRqst(LockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
setRqst(OpenTxnRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
setRqst(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
setRqst(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
setRqst(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
setRqstIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
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
 
setRunas(String) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setRunAs(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setRunAs(long, String) - Method in class org.apache.hadoop.hive.metastore.txn.CompactionTxnHandler
Sets the user to run as.
setRunasIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setRunAsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setRunAsync(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setRunAsyncIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setRunDisabled(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
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
 
setSavepoint() - Method in class org.apache.hive.jdbc.HiveConnection
 
setSavepoint(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
setScale(short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
This setter is only for de-serialization, should not be used otherwise.
setScale(int) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
setScale(int, int) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
setScale(short) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setScale(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
optional uint32 scale = 6;
setScale(int) - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
setScale(Integer) - Method in class org.apache.hive.service.cli.TypeQualifiers
 
setScaleIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setScanAuthorizations(JobConf, Authorizations) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
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
 
setSchema(Job, HCatSchema) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
 
setSchema(Configuration, HCatSchema) - Static method in class org.apache.hive.hcatalog.mapreduce.HCatOutputFormat
Set the schema for the data being written out to the partition.
setSchema(TableSchema) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
setSchema(String) - Method in class org.apache.hive.jdbc.HiveConnection
 
setSchema(List<String>, List<String>) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setSchema(List<String>, List<String>, List<JdbcColumnAttributes>) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setSchema(TTableSchema) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
setSchemaIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
setSchemaName(String) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setSchemaName(String) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setSchemaName(String) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setSchemaName(String) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setSchemaNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setSchemaNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setSchemaNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setSchemaNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setSchemaRetriever(AvroSchemaRetriever) - Method in class org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector
Set the AvroSchemaRetriever for the AvroLazyObjectInspector to the given class
setSchemaVerified(boolean) - Static method in class org.apache.hadoop.hive.metastore.ObjectStore
 
setSchemaVersion(String) - Method in class org.apache.hadoop.hive.metastore.model.MVersionTable
 
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
 
setScrollable(boolean) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setSecond(S) - Method in class org.apache.hadoop.hive.common.ObjectPair
 
setSecret(byte[]) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setSecret(ByteBuffer) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
setSecretIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
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
 
setSelectOperators(List<SelectOperator>) - 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
 
setSemiShared() - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the lock to be semi-shared.
setSeparator(int, byte) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters
 
setSerDe(SerDe, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setSerde(String) - Method in class org.apache.hadoop.hive.ql.parse.StorageFormat
 
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
 
setSerdeInfo(SerDeInfo) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSerDeInfo(MSerDeInfo) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setSerdeInfoIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSerdeName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSerdeParam(SerDeInfo, Properties, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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.metastore.api.SerDeInfo
 
setSerializationLib(String) - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
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
 
setSerializationLibIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
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
 
setServerProtocolVersion(TProtocolVersion) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setServerProtocolVersionIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setSessionHandle(TSessionHandle) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setSessionHandleIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
setSessionId(THandleIdentifier) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
setSessionIdIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
setSessionManager(SessionManager) - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
Set the session manager for the session
setSessionManager(SessionManager) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
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
 
setSessionString(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext.Builder
 
setSessionUGI(String) - Method in class org.apache.hive.service.cli.session.HiveSessionImplwithUGI
 
setSessionVars(Map<String, String>) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setShared() - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the lock to be shared.
setSharedSDPartitionSpec(PartitionSpecWithSharedSD) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setSharedSDPartitionSpecIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setShort(String, HCatSchema, Short) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setShort(String, short) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setShort(int, short) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setShort(int, short) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setShowColumnsDesc(ShowColumnsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowCompactionsDesc(ShowCompactionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowConfDesc(ShowConfDesc) - 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
 
setShuffleGroup() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
setShuffleNone() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
setShuffleSort() - Method in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
setSignature(ArrayList<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
setSignBitInt(int, boolean) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
Turn on or off the highest bit of an int value.
setSignBitLong(long, boolean) - Static method in class org.apache.hadoop.hive.common.type.SqlMathUtil
Turn on or off the highest bit of a long value.
setSignum(byte) - Method in class org.apache.hadoop.hive.common.type.Decimal128
This setter is only for de-serialization, should not be used otherwise.
setSink(ListSinkOperator) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSIntString(Set<IntString>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
setSIntStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
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.metastore.api.SkewedInfo
 
setSkewedColNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setSkewedColNamesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setSkewedColValueLocationMaps(Map<List<String>, String>) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setSkewedColValueLocationMaps(Map<MStringList, String>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setSkewedColValueLocationMapsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setSkewedColValues(List<List<String>>) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setSkewedColValues(List<MStringList>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setSkewedColValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
setSkewedInfo(SkewedInfo) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSkewedInfo(SkewedInfo) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSkewedInfoIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
setSkipTag(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
setSkipTag(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setSmallIntValue(short) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
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.
setSmbMapJoinOps(Set<SMBMapJoinOperator>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setSortableSortOrders(boolean[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer
 
setSortByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Sort By AST for the clause.
setSortColNames(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
setSortCols(List<Order>) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSortCols(List<MOrder>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setSortColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDynamicListDesc
 
setSource(Operator<?>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSource_db(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setSource_dbIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setSource_table_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
setSource_table_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
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
 
setSourceTableInputFormat(String) - Method in class org.apache.hadoop.hive.ql.io.merge.MergeFileWork
 
setSourceTask(Task) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setSparkConfigUpdated(boolean) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
SetSparkReducerParallelism - Class in org.apache.hadoop.hive.ql.optimizer.spark
SetSparkReducerParallelism determines how many reducers should be run for a given reduce sink, clone from SetReducerParallelism.
SetSparkReducerParallelism() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SetSparkReducerParallelism
 
setSparkSession(SparkSession) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
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
 
setSpill(boolean) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
setSpillPartitionId(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
Set the spill partition id.
setSplitSample(SplitSample) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSPPath(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setSQLState(String) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setSqlState(String) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setSqlState(String) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setSQLStateIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setSqlStateIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setSqlStateIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setSQLXML(String, SQLXML) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setSQLXML(int, SQLXML) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setSQLXML(int, SQLXML) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
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
 
setSrcLocal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setSrcs(String[]) - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
setSSIsSilent(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.setIsSilent().
setStackTraces(Map<String, List<List<String>>>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setStageAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageGraph(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageGraphIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageID(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setStageIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageList(List<Stage>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageType(StageType) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
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(long) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
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(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
setStartIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setStartOffset(long) - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
setStartOffset(long) - Method in class org.apache.hive.service.cli.RowBasedSet
 
setStartOffset(long) - Method in interface org.apache.hive.service.cli.RowSet
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
setStartRowOffset(long) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setStartRowOffsetIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
setState(LockState) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
setState(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setState(LockState) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setState(TxnState) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setState(JobTrackerState) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setState(OperationState) - Method in class org.apache.hive.service.cli.operation.Operation
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setStatement(Statement) - Method in interface org.apache.hive.beeline.BeeLineSignalHandler
 
setStatement(Statement) - Method in class org.apache.hive.beeline.SunSignalHandler
 
setStatement(String) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
setStatementIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
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(int, OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
setStatistics(int, OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.ColumnStatistics statistics = 7;
setStatistics(OrcProto.ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
setStatistics(OrcProto.ColumnStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry.Builder
optional .orc.proto.ColumnStatistics statistics = 2;
setStatistics(Statistics) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setStatistics(Statistics) - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
setStats_obj(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
setStats_obj(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
setStats_objIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
setStats_objIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
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
 
setStatsData(ColumnStatisticsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setStatsDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
setStatsDesc(ColumnStatisticsDesc) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
setStatsDescIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
setStatsDir(HiveConf) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
setStatsObj(List<ColumnStatisticsObj>) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
setStatsObjIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
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
 
setStatus(String) - Method in class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setStatus(TStatus) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
setStatusCode(TStatusCode) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setStatusCodeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
setStatusIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
setStmtHandle(TOperationHandle) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setStopRow(byte[]) - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
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
 
setStoragePolicy(Path, HadoopShims.StoragePolicyValue) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.StoragePolicyShim
 
setStoragePolicy(Path, HadoopShims.StoragePolicyValue) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.StoragePolicyShim
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
setStoredAsSubDirectoriesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setStoreLocation(String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatStorer
 
setStreamAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setStreams(int, OrcProto.Stream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
setStreams(int, OrcProto.Stream.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
repeated .orc.proto.Stream streams = 1;
setString(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
setString(String, HCatSchema, String) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setString(String, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setString(int, String) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setString(int, String) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setStringStatistics(OrcProto.StringStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
setStringStatistics(OrcProto.StringStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.StringStatistics stringStatistics = 4;
setStringStats(StringColumnStatsData) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
setStringStats(Long, Long, Long, Double) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setStringStats(Long, Long, Long, Double) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setStringVal(TStringColumn) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
setStringVal(TStringValue) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
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
 
setStringValue(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
setStringValue(String) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
setStringValue(String) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
setStripeInformation(StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
setStripes(int, OrcProto.StripeInformation) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
setStripes(int, OrcProto.StripeInformation.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.StripeInformation stripes = 3;
setStripeStatistics(OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
setStripeStats(int, OrcProto.StripeStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
setStripeStats(int, OrcProto.StripeStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata.Builder
repeated .orc.proto.StripeStatistics stripeStats = 1;
setStruct(String, HCatSchema, List<? extends Object>) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setStructEntry(TStructTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
Modify the value of a field.
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
setSubqAlias(String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setSubQueryDef(QBSubQuery) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setSubtypes(int, int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Builder
repeated uint32 subtypes = 2 [packed = true];
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
setSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setSuccess(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setSuccess(AddPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setSuccess(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setSuccess(LockResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setSuccess(DropPartitionsResult) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setSuccess(FireEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
setSuccess(AggrStats) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setSuccess(CurrentNotificationEventId) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
setSuccess(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setSuccess(Function) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
setSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setSuccess(List<Index>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setSuccess(NotificationEventResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
setSuccess(GetOpenTxnsInfoResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
setSuccess(GetOpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
setSuccess(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setSuccess(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setSuccess(PartitionsByExprResult) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setSuccess(List<PartitionSpec>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setSuccess(PartitionsStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setSuccess(GetPrincipalsInRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
setSuccess(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setSuccess(GetRoleGrantsForPrincipalResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setSuccess(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setSuccess(List<Table>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setSuccess(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setSuccess(TableStatsResult) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setSuccess(Map<String, Type>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setSuccess(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setSuccess(GrantRevokePrivilegeResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
setSuccess(GrantRevokeRoleResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setSuccess(HeartbeatTxnRangeResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setSuccess(List<HiveObjectPrivilege>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setSuccess(List<Role>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setSuccess(LockResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setSuccess(OpenTxnsResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
setSuccess(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setSuccess(long) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
setSuccess(ShowCompactResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
setSuccess(ShowLocksResponse) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setSuccess(HiveClusterStatus) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setSuccess(QueryPlan) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setSuccess(Schema) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setSuccess(Schema) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setSuccess(TCancelDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
setSuccess(TCancelOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
setSuccess(TCloseOperationResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
setSuccess(TCloseSessionResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
setSuccess(TExecuteStatementResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
setSuccess(TFetchResultsResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
setSuccess(TGetCatalogsResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
setSuccess(TGetColumnsResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
setSuccess(TGetDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
setSuccess(TGetFunctionsResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
setSuccess(TGetInfoResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
setSuccess(TGetOperationStatusResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
setSuccess(TGetResultSetMetadataResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
setSuccess(TGetSchemasResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
setSuccess(TGetTablesResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
setSuccess(TGetTableTypesResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
setSuccess(TGetTypeInfoResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
setSuccess(TOpenSessionResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
setSuccess(TRenewDelegationTokenResp) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
setSuccessful(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setSuccessfulIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
setSum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics.Builder
optional sint64 sum = 1;
setSum(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
setSum(double) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics.Builder
optional double sum = 3;
setSum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics.Builder
optional sint64 sum = 3;
setSum(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics.Builder
optional sint64 sum = 3;
setSumBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics.Builder
optional string sum = 3;
setSuppliedAuthorityList(String[]) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
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(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
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.AppMasterEventDesc
 
setTable(Table) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTable(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setTable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
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.
SettableBinaryObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
SettableBooleanObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableBooleanObjectInspector can set a boolean value to an object.
SettableByteObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableByteObjectInspector can set a byte value to an object.
SettableConfigUpdater - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Helper class that can be used by authorization implementations to set a default list of 'safe' HiveConf parameters that can be edited by user.
SettableConfigUpdater() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.SettableConfigUpdater
 
SettableDateObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableDecimalObjectInspector can set a Date value to an object.
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
 
SettableDoubleObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableDoubleObjectInspector can set a double value to an object.
SettableFloatObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableFloatObjectInspector can set a float value to an object.
SettableHiveCharObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
SettableHiveDecimalObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableDecimalObjectInspector can set a HiveDecimal value to an object.
SettableHiveIntervalDayTimeObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableHiveIntervalDayTimeObjectInspector can set a IntervalDayTime value to an object.
SettableHiveIntervalYearMonthObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableHiveIntervalYearMonthObjectInspector can set a IntervalYearMonth value to an object.
SettableHiveVarcharObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
setTableInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
SettableIntObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableIntObjectInspector can set an int value to an object.
SettableListObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
SettableListObjectInspector.
SettableLongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableLongObjectInspector can set a long value to an object.
SettableMapObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
SettableMapObjectInspector.
setTableName(RangeInputSplit, String) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
Sets the table name on a RangeInputSplit, accounting for change in method name.
setTablename(String) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setTablename(String) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setTablename(String) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setTablename(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setTablename(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.LockComponentBuilder
Set the table name.
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.model.MNotificationLog
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnStatistics
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnStatistics
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Setter for name of the table.
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
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.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
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
 
setTableName(String) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setTableName(String) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setTablenameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
setTablenameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
setTablenameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
setTablenameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setTablenameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
setTableNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setTableSample(TableSample) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setTableScan(TableScanOperator) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
setTableScanOperator(TableScanOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
SettableShortObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableShortObjectInspector can set a short value to an object.
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
 
setTableSpec(BaseSemanticAnalyzer.TableSpec) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTableStats(List<ColumnStatisticsObj>) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
setTableStatsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
SettableStringObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableStringObjectInspector can set a string value to an object.
SettableStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
SettableStructObjectInspector.
SettableStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
 
SettableTimestampObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
setTableType(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setTableType(TableType) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTableTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableTypes(List<String>) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
setTableTypesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
SettableUDF - Interface in org.apache.hadoop.hive.ql.udf
THIS INTERFACE IS UNSTABLE AND SHOULD NOT BE USED BY 3RD PARTY UDFS.
SettableUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
SettableUnionObjectInspector.
SettableUnionObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SettableUnionObjectInspector
 
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
 
setTabSize(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
setTag(byte) - Method in class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
setTag(int) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setTag(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setTag(byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
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
 
setTargetColumnName(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
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
 
setTaskAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
setTaskCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskList(List<Task>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setTaskListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
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
 
setTaskTrackers(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setTaskTrackersIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setTaskType(TaskType) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setTbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
setTbl(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
setTbl_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
setTbl_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
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
 
setTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setTblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
setTblLevel(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setTblLvl(boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.AnalyzeRewriteContext
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
setTblName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
setTblNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
setTblNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
setTblNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
setTblNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
setTblNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
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
 
setTemplate(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setTemplateBaseDir(String) - Method in class org.apache.hadoop.hive.ant.GenVectorCode
 
setTemplateFile(String) - Method in class org.apache.hadoop.hive.ant.GenHiveTemplate
 
setTemplatePath(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setTemporary(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTemporary(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setTemporary(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setTemporary(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTemporaryIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTestDataDirectory(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setTestScriptDirectory(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setTezProcessorContext(ProcessorContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
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
 
setThreadId(int) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreThread
Set the id for this thread.
setThrow_exception(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
setThrow_exceptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
setThrowException(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
setTime(long) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
setTime(String, Time) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTime(String, Time, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTime(int, Time) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTime(int, Time) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
setTimestamp(Timestamp, byte[], int) - Static method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
setTimestamp(String, HCatSchema, Timestamp) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
setTimestamp(String, Timestamp) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTimestamp(String, Timestamp, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setTimestampStatistics(OrcProto.TimestampStatistics) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
setTimestampStatistics(OrcProto.TimestampStatistics.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics.Builder
optional .orc.proto.TimestampStatistics timestampStatistics = 9;
setTimeVar(Configuration, HiveConf.ConfVars, long, TimeUnit) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setTimeVar(HiveConf.ConfVars, long, TimeUnit) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setTmpHDFSPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
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
 
setToCache(boolean) - Method in class org.apache.hadoop.hive.ql.exec.spark.MapInput
 
setToken_owner(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setToken_ownerIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setToken_str_form(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setToken_str_form(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setToken_str_formIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setToken_str_formIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setTokenIdentifier(String) - Method in class org.apache.hadoop.hive.metastore.model.MDelegationToken
 
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.
setTokenStr(String) - Method in class org.apache.hadoop.hive.metastore.model.MDelegationToken
 
setTokenStr(UserGroupInformation, String, String) - Static method in class org.apache.hadoop.hive.shims.Utils
Create a delegation token object for the given token string and service.
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
 
setTotalFiles(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTotalInMemRowCount(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
 
setTotalLength(Long) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setTotalOrderPartitionFile(JobConf, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
setTotalOrderPartitionFile(JobConf, Path) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
setTotalOrderPartitionFile(JobConf, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
The method sets to set the partition file has a different signature between hadoop versions.
setTPartition(Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
setTraits(OpTraits) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setTraits(OpTraits) - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
setTransactionId(long) - Method in class org.apache.hadoop.hive.metastore.LockRequestBuilder
Set the transaction id.
setTransactionId(long) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTransactionIsolation(int) - Method in class org.apache.hive.jdbc.HiveConnection
 
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
 
setTransportLock(ReentrantLock) - Method in class org.apache.hive.jdbc.HiveQueryResultSet.Builder
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
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
 
setTxn_high_water_mark(long) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
setTxn_high_water_mark(long) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
setTxn_high_water_markIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
setTxn_high_water_markIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
setTxn_ids(List<Long>) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
setTxn_idsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setTxnid(long) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setTxnidIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setTxns(HeartbeatTxnRangeRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
setTxnsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
setTyp(Entity.Type) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setType(CompactionType) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setType(String) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setType(LockType) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setType(CompactionType) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setType(LockType) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setType(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setType(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
setType(String) - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
setType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPrincipalDesc
 
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
 
setType(TTypeId) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setType1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setType2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setTypeCheckCtx(TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setTypeClassName(String) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
setTypeClassNameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
setTypeDesc(TTypeDesc) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
setTypeDescIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
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.
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
setTypeIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
setTypeMap(Map<String, Class<?>>) - Method in class org.apache.hive.jdbc.HiveConnection
 
setTypeName(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setTypeName(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharTypeInfo
 
setTypeName(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
setTypeName(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
setTypeQualifiers(TTypeQualifiers) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
setTypeQualifiers(TypeQualifiers) - Method in class org.apache.hive.service.cli.TypeDescriptor
 
setTypeQualifiersIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
setTypes(List<OrcProto.Type>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
setTypes(int, OrcProto.Type) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
setTypes(int, OrcProto.Type.Builder) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer.Builder
repeated .orc.proto.Type types = 4;
setTypes(List<TTypeEntry>) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
setTypesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
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
 
setUnderscore_int(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setUnderscore_intIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setUnionEntry(TUnionTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setUnionField1(PropValueUnion) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionField1IsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionField2(PropValueUnion) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionField2IsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionField3(PropValueUnion) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionField3IsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setUnionMStringString(Map<String, String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
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
 
setUnscaled(byte[]) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setUnscaled(ByteBuffer) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setUnscaledIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
setUnscaledValue(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.Decimal128
This setter is only for de-serialization, should not be used otherwise.
setUnsupportedFeature(CalciteSemanticException.UnsupportedFeature) - Method in exception org.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticException
 
setup(Scan, Configuration) - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
setup(HiveConf) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager
Initialize based on given configuration.
setup(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
 
setupConfiguration(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniMrShim
 
setupConfiguration(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniMrShim
 
setupConfiguration(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniSparkShim
 
setupConfiguration(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniTezShim
 
setupConfiguration(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniMrShim
 
setupConsoleReader() - Method in class org.apache.hadoop.hive.cli.CliDriver
 
setupContext(List<Path>) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
used for bucket map join
setUpdateColumnAccessInfo(ColumnAccessInfo) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
setUpdateLocations(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMDatabaseURIRetVal
 
setUpdateLocations(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateMStorageDescriptorTblURIRetVal
 
setUpdateLocations(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdatePropURIRetVal
 
setUpdateLocations(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore.UpdateSerdeURIRetVal
 
setUpdateOrDelete(boolean) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
setupJob(JobContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
setupKeysWrapper(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
setupMapWork(MapWork, GenTezProcContext, PrunedPartitionList, Operator<? extends OperatorDesc>, String) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
setupMapWork(MapWork, GenSparkProcContext, PrunedPartitionList, Operator<? extends OperatorDesc>, String) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
setupNeededColumns(TableScanOperator, RowSchema, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
setupObjectRegistry(ObjectRegistry) - Static method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
setupOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
check structure of Arguments: First arg should be a String then there should be an even number of Arguments: String, expression; expression should be Convertible to Boolean.
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
 
setupOverflowBatch() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
setupPartitionOutputOI(SerDe, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
setupPermissionsForBuiltinUDFs(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Setup blocked flag for all builtin UDFs as per udf whitelist and blacklist
setupPermissionsForUDFs(String, String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
Setup blocked flag for all builtin UDFs as per udf whitelist and blacklist
setupPool(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
setupQueryCurrentTimestamp() - Method in class org.apache.hadoop.hive.ql.session.SessionState
Initialize current timestamp, other necessary query initialization.
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
 
setupReduceSink(GenTezProcContext, ReduceWork, ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
setupReduceSink(GenSparkProcContext, ReduceWork, ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat.MultiOutputCommitter
 
setupVOutContext(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
Setup the vectorized row batch description of the output of the native vectorized map join operator.
setupWriter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setUri(String) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
setUri(String) - Method in class org.apache.hadoop.hive.metastore.model.MResourceUri
 
setUriIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
setURL(String, URL) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setURL(int, URL) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
setURL(int, URL) - Method in class org.apache.hive.jdbc.HivePreparedStatement
 
setUseBucketizedHiveInputFormat(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Before setting this to true make sure it's not reading ACID tables
setUseBucketizedHiveInputFormat(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setUseOneNullRowInputFormat(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setUser(String) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setUser(String) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setUser(String) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setUser(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setUser(String) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setUser(String) - Method in class org.apache.hadoop.hive.metastore.LockRequestBuilder
 
setUser(String) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
setUserArgs(Map<String, Object>) - Method in class org.apache.hive.hcatalog.templeton.tool.JobState
 
setUserDefinedTypeEntry(TUserDefinedTypeEntry) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
setUserIpAddress(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext.Builder
 
setUserIpAddress(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
set the ip address for user running the query
setUserIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
setUserIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
setUserIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
setUserIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
setUserLevelExplain(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setUserMetadata(List<OrcProto.UserMetadataItem>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
setUserName(String) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
setUserName(String) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setUserName(String) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
setUsername(String) - Method in class org.apache.hive.beeline.util.QFileClient
 
setUserName(String) - Method in interface org.apache.hive.service.cli.session.HiveSessionBase
 
setUserName(String) - Method in class org.apache.hive.service.cli.session.HiveSessionImpl
 
setUserName(String) - Static method in class org.apache.hive.service.cli.session.SessionManager
 
setUsername(String) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setUsernameIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
setUserPrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setUserPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setUseSorted(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setUsesScript(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setV(int[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This setter is only for de-serialization, should not be used otherwise.
setV0(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Setter for v0.
setV1(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Setter for v1.
setV2(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Setter for v2.
setV3(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Setter for v3.
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(String, int) - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
Sets the string value to a new value, obeying the max length defined for this object.
setValue(HiveBaseChar, int) - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
setValue(String, int) - Method in class org.apache.hadoop.hive.common.type.HiveChar
Set char value, padding or truncating the value to the size of len parameter.
setValue(String) - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
setValue(String) - Method in class org.apache.hadoop.hive.common.type.HiveVarchar
Set the new value
setValue(HiveVarchar) - Method in class org.apache.hadoop.hive.common.type.HiveVarchar
 
setValue(Object) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Set the typed bytes from a given Java object.
setValue(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
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.gen.DateColAddIntervalDayTimeScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColAddIntervalYearMonthScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractDateScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalDayTimeScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractIntervalYearMonthScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateColSubtractTimestampScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalDayTimeColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarAddIntervalYearMonthColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractDateColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalDayTimeColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractIntervalYearMonthColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DateScalarSubtractTimestampColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColAddLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColDivideLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColGreaterLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColLessLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColModuloLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColMultiplyLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColNotEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleColSubtractLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarAddLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarDivideLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarGreaterLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarLessLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarModuloLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarMultiplyLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarNotEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.DoubleScalarSubtractLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColGreaterLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColLessLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleColNotEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarGreaterLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarLessLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualDoubleColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterDoubleScalarNotEqualLongColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColGreaterLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColLessLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongColNotEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarGreaterLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarLessLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterLongScalarNotEqualLongColumn
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeColAddDateScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalDayTimeScalarAddDateColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddDateScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthColAddTimestampScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddDateColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.IntervalYearMonthScalarAddTimestampColumn
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColAddLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColDivideDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColGreaterLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessDoubleScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessEqualLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColLessLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColModuloLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColMultiplyLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColNotEqualLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractDoubleScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongColSubtractLongScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarAddLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarDivideDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarGreaterLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarLessLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarModuloLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarMultiplyLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarNotEqualLongColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractDoubleColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.LongScalarSubtractLongColumn
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
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.StringGroupColConcatStringScalar
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringScalarConcatStringGroupCol
 
setValue(Object, ColumnVector, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
setValue(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem.Builder
optional bytes value = 2;
setValue(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
setValue(LazyHiveChar) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveChar
 
setValue(LazyHiveVarchar) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveVarchar
 
setValue(boolean) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
setValue(byte) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
setValue(double) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
setValue(short) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
setValue(int) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
setValue(long) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
setValue(String) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
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
 
setValueFilteredTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setValueIndex(int[]) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
setValueIndices(Map<Byte, int[]>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
setValueIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
setValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
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
setValues(List<ByteBuffer>) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setValues(List<Boolean>) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setValues(List<Byte>) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setValues(List<Double>) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setValues(List<Short>) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setValues(List<Integer>) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setValues(List<Long>) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setValues(List<String>) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
setValueSerializeInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
setValuesIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
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
 
setValueTypePtr(int) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
setValueTypePtrIsSet(boolean) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
setValueWriters(VectorExpressionWriter[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
setVar(Configuration, HiveConf.ConfVars, String) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setVar(HiveConf.ConfVars, String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setVarchar(String, HCatSchema, HiveVarchar) - Method in class org.apache.hive.hcatalog.data.HCatRecord
 
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.
setVariable(String, String) - Static method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
setVectorColumnNameMap(Map<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setVectorColumnTypeMap(Map<Integer, String>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setVectorDesc(VectorGroupByDesc) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setVectorDesc(VectorMapJoinDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setVectorGroupBatches(boolean) - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
setVectorMode(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setVectorOutput(boolean) - Method in class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
setVectorScratchColumnTypeMap(Map<Integer, String>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setVerbose(boolean) - Method in class org.apache.hive.beeline.HiveSchemaTool
 
setVersion(String) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setVersion(OrcFile.Version) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper
 
setVersion(int, int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
repeated uint32 version = 4 [packed = true];
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.
setVersionComment(String) - Method in class org.apache.hadoop.hive.metastore.model.MVersionTable
 
setVersionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setVertexName(String) - Method in class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
setVertexType(BaseWork, TezWork.VertexType) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
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.metastore.api.Table
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewExpandedTextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setViewName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewOriginalTextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
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
 
setWindowingFunctionHelpers(Map<String, WindowingTableFunction.WindowingFunctionInfoHelper>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
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
 
setWorkerid(String) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setWorkeridIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
setWorkflowAdjacencies(Configuration, QueryPlan) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
setWriteBlockAsReadBlock() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setWritePoint(long) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
setWriterTimezone(String) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
setWriterTimezoneBytes(ByteString) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter.Builder
optional string writerTimezone = 3;
setWriterVersion(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript.Builder
optional uint32 writerVersion = 6;
setWriteType(WriteEntity.WriteType) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Only use this if you are very sure of what you are doing.
setWriteType(AcidUtils.Operation) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setZookeeperClientKerberosJaasConfig(String, String) - Static method in class org.apache.hadoop.hive.shims.Utils
Dynamically sets up the JAAS configuration that uses kerberos
setZooKeeperEnsemble(String) - Method in class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 
setZooKeeperInstance(JobConf, Class<?>, String, String, boolean) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Wrapper around setZooKeeperInstance(Configuration, ClientConfiguration) which only exists in 1.6.0 and newer.
setZooKeeperInstance(JobConf, String, String, boolean) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableInputFormat
 
sh(String) - Method in class org.apache.hive.beeline.Commands
 
ShapeDetails - Class in org.apache.hadoop.hive.ql.plan.ptf
 
ShapeDetails() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
shareStateWith(FunctionInfo) - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
ShellCmdExecutor - Class in org.apache.hadoop.hive.common.cli
 
ShellCmdExecutor(String, PrintStream, PrintStream) - Constructor for class org.apache.hadoop.hive.common.cli.ShellCmdExecutor
 
shiftLeft(SignedInt128, SignedInt128, int) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
shiftLeftConstructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
shiftLeftDestructive(int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Left-shift for the given number of bits.
shiftLeftDestructive(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Left-shift for the given number of bits.
shiftLeftDestructiveCheckOverflow(int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Left-shift for the given number of bits.
shiftRight(SignedInt128, SignedInt128, int, boolean) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
This version returns the result as a new object, not modifying the give objects.
shiftRightConstructive(int, boolean) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
shiftRightDestructive(int, boolean) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Right-shift for the given number of bits.
shiftRightDestructive(int, boolean) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Right-shift for the given number of bits.
shiftVColsSet(Set<Integer>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
ShimLoader - Class in org.apache.hadoop.hive.shims
ShimLoader.
SHORT - Static variable in class org.apache.hive.hcatalog.data.DataType
 
SHORT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
SHORT = 2;
ShortObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A ShortObjectInspector inspects an Object representing a Short.
shortTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
shortTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
shortValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
ShortWritable - Class in org.apache.hadoop.hive.serde2.io
ShortWritable.
ShortWritable(short) - Constructor for class org.apache.hadoop.hive.serde2.io.ShortWritable
 
ShortWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.ShortWritable
 
ShortWritable.Comparator - Class in org.apache.hadoop.hive.serde2.io
A Comparator optimized for BytesWritable.
ShortWritable.Comparator() - Constructor for class org.apache.hadoop.hive.serde2.io.ShortWritable.Comparator
 
shouldEndBinarySearch() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
shouldIgnoreField(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
shouldIgnoreField(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
shouldRunAsync() - Method in class org.apache.hive.service.cli.operation.Operation
 
shouldSkipCombine(Path, Configuration) - Method in interface org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.AvoidSplitCombination
 
shouldSkipCombine(Path, Configuration) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
shouldStop() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
show_compact(ShowCompactRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_compact_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
show_compact(ShowCompactRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_compact_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
show_compact(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
show_compact(ShowCompactRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
show_compact(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
show_locks(ShowLocksRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_locks_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
show_locks(ShowLocksRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_locks_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
show_locks(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
show_locks(ShowLocksRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
show_locks(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
showCompact(ShowCompactRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
showCompactions() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
showCompactions() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a list of all current compactions.
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.
ShowCompactRequest - Class in org.apache.hadoop.hive.metastore.api
 
ShowCompactRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
ShowCompactRequest(ShowCompactRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
Performs a deep copy on other.
ShowCompactRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ShowCompactResponse - Class in org.apache.hadoop.hive.metastore.api
 
ShowCompactResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
ShowCompactResponse(List<ShowCompactResponseElement>) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
ShowCompactResponse(ShowCompactResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
Performs a deep copy on other.
ShowCompactResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ShowCompactResponseElement - Class in org.apache.hadoop.hive.metastore.api
 
ShowCompactResponseElement() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
ShowCompactResponseElement(String, String, CompactionType, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
ShowCompactResponseElement(ShowCompactResponseElement) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
Performs a deep copy on other.
ShowCompactResponseElement._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ShowConfDesc - Class in org.apache.hadoop.hive.ql.plan
 
ShowConfDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowConfDesc
 
ShowConfDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowConfDesc
 
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
 
showCurrentRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
showFunctionIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
ShowFunctionsDesc(Path, String, boolean) - 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) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
showGrants() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ShowIndexesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowIndexesDesc.
ShowIndexesDesc(String, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
showInfo() - Method in class org.apache.hive.beeline.HiveSchemaTool
Print Hive version and schema version
showJobId(String) - Method in class org.apache.hive.hcatalog.templeton.Server
Return the status of the jobid.
showJobList(String, boolean, String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Return all the known job ids for this user based on the optional filter conditions.
showLocks() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
showLocks() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Show all currently held and waiting locks.
showLocks(ShowLocksRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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
 
ShowLocksRequest - Class in org.apache.hadoop.hive.metastore.api
 
ShowLocksRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
ShowLocksRequest(ShowLocksRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
Performs a deep copy on other.
ShowLocksRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ShowLocksResponse - Class in org.apache.hadoop.hive.metastore.api
 
ShowLocksResponse() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
ShowLocksResponse(List<ShowLocksResponseElement>) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
ShowLocksResponse(ShowLocksResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
Performs a deep copy on other.
ShowLocksResponse._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ShowLocksResponseElement - Class in org.apache.hadoop.hive.metastore.api
 
ShowLocksResponseElement() - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
ShowLocksResponseElement(long, String, LockState, LockType, long, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
ShowLocksResponseElement(ShowLocksResponseElement) - Constructor for class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
Performs a deep copy on other.
ShowLocksResponseElement._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.HiveV1Authorizer
 
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
showRoleGrants() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showRolePrincipals() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showRoles() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showStmtIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
showTxns() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
showTxns() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Show the list of currently open transactions.
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.
shrinkedLength - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
shrinkSplit(long) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
shuffle(JavaPairRDD<HiveKey, BytesWritable>, int) - Method in class org.apache.hadoop.hive.ql.exec.spark.GroupByShuffler
 
shuffle(JavaPairRDD<HiveKey, BytesWritable>, int) - Method in class org.apache.hadoop.hive.ql.exec.spark.SortByShuffler
 
shuffle(JavaPairRDD<HiveKey, BytesWritable>, int) - Method in interface org.apache.hadoop.hive.ql.exec.spark.SparkShuffler
 
SHUFFLE_GROUP - Static variable in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
SHUFFLE_NONE - Static variable in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
SHUFFLE_SORT - Static variable in class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
shuffleBytesWritten - Variable in class org.apache.hive.spark.client.metrics.ShuffleWriteMetrics
Number of bytes written for the shuffle by tasks.
shuffleReadMetrics - Variable in class org.apache.hive.spark.client.metrics.Metrics
If tasks read from shuffle output, metrics on getting shuffle data.
ShuffleReadMetrics - Class in org.apache.hive.spark.client.metrics
Metrics pertaining to reading shuffle data.
ShuffleReadMetrics(int, int, long, long) - Constructor for class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
 
ShuffleReadMetrics(TaskMetrics) - Constructor for class org.apache.hive.spark.client.metrics.ShuffleReadMetrics
 
ShuffleTran - Class in org.apache.hadoop.hive.ql.exec.spark
 
ShuffleTran(SparkPlan, SparkShuffler, int) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.ShuffleTran
 
ShuffleTran(SparkPlan, SparkShuffler, int, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.ShuffleTran
 
shuffleWriteMetrics - Variable in class org.apache.hive.spark.client.metrics.Metrics
If tasks wrote to shuffle output, metrics on the written shuffle data.
ShuffleWriteMetrics - Class in org.apache.hive.spark.client.metrics
Metrics pertaining to writing shuffle data.
ShuffleWriteMetrics(long, long) - Constructor for class org.apache.hive.spark.client.metrics.ShuffleWriteMetrics
 
ShuffleWriteMetrics(TaskMetrics) - Constructor for class org.apache.hive.spark.client.metrics.ShuffleWriteMetrics
 
shuffleWriteTime - Variable in class org.apache.hive.spark.client.metrics.ShuffleWriteMetrics
Time tasks spent blocking on writes to disk or buffer cache, in nanoseconds.
shutdown() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
shutdown() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
shutdown() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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 interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager
Shutdown the session manager.
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManagerImpl
 
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniDFSShim
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims.MiniMrShim
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniDFSShim
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniMrShim
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniSparkShim
 
shutdown() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims.MiniTezShim
 
shutdown() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
shutdown() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniMrShim
 
SHUTDOWN_HOOK_PRIORITY - Static variable in class org.apache.hive.common.util.HiveStringUtils
Priority of the StringUtils shutdown hook.
ShutdownHookManager - Class in org.apache.hive.common.util
The ShutdownHookManager enables running shutdownHook in a deterministic order, higher priority first.
sign(int, HiveDecimal, LongColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
sign(int, HiveDecimalWritable, 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
 
signCookie(String) - Method in class org.apache.hive.service.CookieSigner
Sign the cookie given the string token as input.
SignedInt128 - Class in org.apache.hadoop.hive.common.type
This code was based on code from Microsoft's PolyBase.
SignedInt128() - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Empty constructor to construct zero.
SignedInt128(long) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Construct this object from a long value.
SignedInt128(UnsignedInt128) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Construct this object from UnsignedInt128.
SignedInt128(SignedInt128) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Copy Constructor.
SignedInt128(int, int, int, int) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Construct this object from the given integers.
SignedInt128(String) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Constructs from the given string.
SignedInt128(char[], int, int) - Constructor for class org.apache.hadoop.hive.common.type.SignedInt128
Constructs from the given string with given offset and length.
signum() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
Get the sign of the underlying decimal.
SimpleCharStream - Class in org.apache.hadoop.hive.serde2.dynamic_type
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(Reader, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(Reader) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream, String) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleCharStream(InputStream) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
SimpleExceptionMapper - Class in org.apache.hive.hcatalog.templeton
Map our exceptions to the Jersey response.
SimpleExceptionMapper() - Constructor for class org.apache.hive.hcatalog.templeton.SimpleExceptionMapper
 
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
 
simpleHostname(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Given a full hostname, return the word upto the first dot.
SimpleMapEqualComparer - Class in org.apache.hadoop.hive.serde2.objectinspector
 
SimpleMapEqualComparer() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SimpleMapEqualComparer
 
SimpleNode - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
SimpleNode(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
SimpleNode(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
simpleSelectStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SimpleWebException - Exception in org.apache.hive.hcatalog.templeton
Simple exception that will return a json error payload if thrown from a JAX web server.
SimpleWebException(int, String) - Constructor for exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
SimpleWebException(int, String, Map<String, Object>) - Constructor for exception org.apache.hive.hcatalog.templeton.SimpleWebException
 
singleFromStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SingleInputFormat - Class in org.apache.hive.hcatalog.templeton.tool
An empty InputFormat.
SingleInputFormat() - Constructor for class org.apache.hive.hcatalog.templeton.tool.SingleInputFormat
 
singleRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator
 
singleRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
singleRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
singleRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator
 
singleRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
size() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
size() - Method in class org.apache.hadoop.hive.hbase.ColumnMappings
 
size() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
size() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
size() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
The number of Partition instances represented by the PartitionSpec.
size() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap
Number of keys in the hashmap
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer
 
size() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinPersistableTableContainer
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer
 
size() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
size() - Method in class org.apache.hadoop.hive.ql.exec.PTFRollingPartition
 
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
 
size() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Returns the number of valid elements.
size() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Write buffer size
size() - Method in class org.apache.hive.hcatalog.api.HCatPartitionSpec
Getter for the number of HCatPartitions represented by this HCatPartitionSpec instance.
size() - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
size() - Method in interface org.apache.hive.hcatalog.data.HCatRecordable
Gets the size of the hcat record.
size() - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
size() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
size() - Method in class org.apache.hive.service.cli.Column
 
SizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
SizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SizeBasedBigTableSelectorForAutoSMJ
 
sizeInBytes() - Method in class org.apache.hive.common.util.BloomFilter
 
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
 
skewedColumnValue() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedColumnValuePair() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedColumnValuePairList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedColumnValues() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SkewedInfo - Class in org.apache.hadoop.hive.metastore.api
 
SkewedInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
SkewedInfo(List<String>, List<List<String>>, Map<List<String>, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
SkewedInfo(SkewedInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.SkewedInfo
Performs a deep copy on other.
SkewedInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
skewedLocationMap() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedLocations() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedLocationsList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedValueElement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
skewedValueLocationElement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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(ParseContext) - 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.common.io.NonSyncByteArrayInputStream
skip(long) - Method in class org.apache.hadoop.hive.conf.LoopingByteArrayInputStream
 
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
 
skip(byte) - Method in interface org.apache.hadoop.hive.serde2.thrift.SkippableTProtocol
 
skip(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Skip past the current field Just increments the field index counter.
skipAuthorization() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
skipAuthorization() - Method in class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
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.
SkippableTProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that can efficiently skip fields when deserializing.
skipRows(long) - Method in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.FloatTreeReader
 
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.
skipType() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Skips a type byte.
skipVectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
skipVLong() - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
skipVLong(WriteBuffers.Position) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
sliceAndShift(long, long, long) - Method in class org.apache.hadoop.hive.common.DiskRange
 
slotPairs - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
slotTriples - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
SMALLINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
SmallintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
SmallintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SmallintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
SmallintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
SmallintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
smallIntValue(short) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
smallTableByteColumnVectorColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
smallTableMapping - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
smallTableOutputVectorColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
smallTableVectorDeserializeRow - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
smbJoinComputeKeys(Object, byte) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
smbJoinComputeKeys(Object, byte) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
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
 
smbMapJoinCtxMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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
 
SNAPPY_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
SNAPPY = 2;
snapshot() - Method in class org.apache.hive.spark.counter.SparkCounters
Create a snapshot of the current counters to send back to the client.
soi - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
soi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
soi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
SortAndDigestPrintStream - Class in org.apache.hadoop.hive.common.io
 
SortAndDigestPrintStream(OutputStream, String) - Constructor for class org.apache.hadoop.hive.common.io.SortAndDigestPrintStream
 
SortBucketJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
SortBucketJoinProcCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
sortByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
sortByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
SortByShuffler - Class in org.apache.hadoop.hive.ql.exec.spark
 
SortByShuffler(boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SortByShuffler
 
sortCols(ArrayList<Order>) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
sortCols(List<Order>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for Sort-cols.
sortedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
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
 
SortPrintStream - Class in org.apache.hadoop.hive.common.io
 
SortPrintStream(OutputStream, String) - Constructor for class org.apache.hadoop.hive.common.io.SortPrintStream
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdCollation
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistinctRowCount
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistribution
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSize
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdUniqueKeys
 
sourceColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
sourceRow - Variable in class org.apache.hadoop.hive.accumulo.LazyAccumuloMap
 
sp - Variable in class org.apache.hive.hcatalog.data.transfer.HCatReader
 
sp - Variable in class org.apache.hive.hcatalog.data.transfer.HCatWriter
 
SPARK_BUILD_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_BUILD_RDD_GRAPH - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_CREATE_TRAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_FLUSH_HASHTABLE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_GENERATE_TASK_TREE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_INIT_OPERATORS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_OPTIMIZE_OPERATOR_TREE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_OPTIMIZE_TASK_TREE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_RUN_JOB - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_RUN_STAGE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_SUBMIT_JOB - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SPARK_SUBMIT_TO_RUNNING - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
SparkBucketMapJoinContext - Class in org.apache.hadoop.hive.ql.plan
 
SparkBucketMapJoinContext(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.SparkBucketMapJoinContext
 
SparkClient - Interface in org.apache.hive.spark.client
Defines the API for the Spark remote client.
SparkClientFactory - Class in org.apache.hive.spark.client
Factory for SparkClient instances.
SparkClientFactory() - Constructor for class org.apache.hive.spark.client.SparkClientFactory
 
SparkClientUtilities - Class in org.apache.hive.spark.client
 
SparkClientUtilities() - Constructor for class org.apache.hive.spark.client.SparkClientUtilities
 
SparkCompiler - Class in org.apache.hadoop.hive.ql.parse.spark
SparkCompiler translates the operator plan into SparkTasks.
SparkCompiler() - Constructor for class org.apache.hadoop.hive.ql.parse.spark.SparkCompiler
 
SparkCounter - Class in org.apache.hive.spark.counter
 
SparkCounter() - Constructor for class org.apache.hive.spark.counter.SparkCounter
 
SparkCounter(String, String, String, long, JavaSparkContext) - Constructor for class org.apache.hive.spark.counter.SparkCounter
 
SparkCounterGroup - Class in org.apache.hive.spark.counter
We use group to fold all the same kind of counters.
SparkCounterGroup(String, String, JavaSparkContext) - Constructor for class org.apache.hive.spark.counter.SparkCounterGroup
 
SparkCounters - Class in org.apache.hive.spark.counter
SparkCounters is used to collect Hive operator metric through Spark accumulator.
SparkCounters(JavaSparkContext) - Constructor for class org.apache.hive.spark.counter.SparkCounters
 
SparkCrossProductCheck - Class in org.apache.hadoop.hive.ql.optimizer.physical
Check each MapJoin and ShuffleJoin Operator to see if they are performing a cross product.
SparkCrossProductCheck() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SparkCrossProductCheck
 
SparkEdgeProperty - Class in org.apache.hadoop.hive.ql.plan
 
SparkEdgeProperty(long, int) - Constructor for class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
SparkEdgeProperty(long) - Constructor for class org.apache.hadoop.hive.ql.plan.SparkEdgeProperty
 
SparkFileSinkProcessor - Class in org.apache.hadoop.hive.ql.parse.spark
FileSinkProcessor handles addition of merge, move and stats tasks for filesinks.
SparkFileSinkProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.spark.SparkFileSinkProcessor
 
SparkHashTableSinkDesc - Class in org.apache.hadoop.hive.ql.plan
Map Join operator Descriptor implementation.
SparkHashTableSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SparkHashTableSinkDesc
 
SparkHashTableSinkDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.SparkHashTableSinkDesc
 
SparkHashTableSinkOperator - Class in org.apache.hadoop.hive.ql.exec
 
SparkHashTableSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator
 
SparkJobRef - Interface in org.apache.hadoop.hive.ql.exec.spark.status
 
SparkJobState - Enum in org.apache.hadoop.hive.ql.exec.spark.status
 
SparkJobStatus - Interface in org.apache.hadoop.hive.ql.exec.spark.status
SparkJobStatus identify what Hive want to know about the status of a Spark job.
SparkJoinHintOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.spark
This processes joins in which user specified a hint to identify the small-table.
SparkJoinHintOptimizer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinHintOptimizer
 
SparkJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.spark
Converts a join to a more optimized join for the Spark path.
SparkJoinOptimizer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinOptimizer
 
SparkMapJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.spark
SparkMapJoinOptimizer cloned from ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicate join when possible.
SparkMapJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkMapJoinOptimizer
 
SparkMapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer
 
SparkMapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SparkMapJoinProcessor
 
SparkMapJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
SparkMapJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SparkMapJoinResolver
 
SparkMapRecordHandler - Class in org.apache.hadoop.hive.ql.exec.spark
Clone from ExecMapper.
SparkMapRecordHandler() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkMapRecordHandler
 
SparkMergeFileRecordHandler - Class in org.apache.hadoop.hive.ql.exec.spark
Copied from MergeFileMapper.
SparkMergeFileRecordHandler() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkMergeFileRecordHandler
 
SparkPlan - Class in org.apache.hadoop.hive.ql.exec.spark
 
SparkPlan() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkPlan
 
SparkPlanGenerator - Class in org.apache.hadoop.hive.ql.exec.spark
 
SparkPlanGenerator(JavaSparkContext, Context, JobConf, Path, SparkReporter) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkPlanGenerator
 
SparkProcessAnalyzeTable - Class in org.apache.hadoop.hive.ql.parse.spark
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.
SparkProcessAnalyzeTable(GenSparkUtils) - Constructor for class org.apache.hadoop.hive.ql.parse.spark.SparkProcessAnalyzeTable
Injecting the utils in the constructor facilitates testing.
SparkRecordHandler - Class in org.apache.hadoop.hive.ql.exec.spark
 
SparkRecordHandler() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkRecordHandler
 
SparkReduceRecordHandler - Class in org.apache.hadoop.hive.ql.exec.spark
Clone from ExecReducer, it is the bridge between the spark framework and the Hive operator pipeline at execution time.
SparkReduceRecordHandler() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkReduceRecordHandler
 
SparkReduceSinkMapJoinProc - Class in org.apache.hadoop.hive.ql.optimizer.spark
 
SparkReduceSinkMapJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc
 
SparkReduceSinkMapJoinProc.SparkMapJoinFollowedByGroupByProcessor - Class in org.apache.hadoop.hive.ql.optimizer.spark
 
SparkReduceSinkMapJoinProc.SparkMapJoinFollowedByGroupByProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc.SparkMapJoinFollowedByGroupByProcessor
 
sparkReporter - Variable in class org.apache.hadoop.hive.ql.exec.spark.HivePairFlatMapFunction
 
SparkReporter - Class in org.apache.hadoop.hive.ql.exec.spark
Implement SparkReporter for Hive operator level statistics collection, and throw UnsupportedOperationException for other unrelated methods, so if any Hive feature depends on these unimplemented methods, we could go back here quickly and enable it.
SparkReporter(SparkCounters) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkReporter
 
sparkSerializationKryo - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
SparkSession - Interface in org.apache.hadoop.hive.ql.exec.spark.session
 
SparkSessionImpl - Class in org.apache.hadoop.hive.ql.exec.spark.session
 
SparkSessionImpl() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
SparkSessionManager - Interface in org.apache.hadoop.hive.ql.exec.spark.session
Defines interface for managing multiple SparkSessions in Hive when multiple users are executing queries simultaneously on Spark execution engine.
SparkSessionManagerImpl - Class in org.apache.hadoop.hive.ql.exec.spark.session
Simple implementation of SparkSessionManager - returns SparkSession when requested through getSession and keeps track of created sessions.
SparkShuffler - Interface in org.apache.hadoop.hive.ql.exec.spark
 
SparkSkewJoinProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.spark
Spark-version of SkewJoinProcFactory.
SparkSkewJoinProcFactory.SparkSkewJoinJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.spark
 
SparkSkewJoinProcFactory.SparkSkewJoinJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinProcFactory.SparkSkewJoinJoinProcessor
 
SparkSkewJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.spark
Spark version of SkewJoinResolver.
SparkSkewJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolver
 
SparkSkewJoinResolver.SparkSkewJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.spark
 
SparkSkewJoinResolver.SparkSkewJoinProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolver.SparkSkewJoinProcCtx
 
SparkSMBJoinHintOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.spark
Converts from a bucket-mapjoin created from hints to SMB mapjoin.
SparkSMBJoinHintOptimizer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSMBJoinHintOptimizer
 
SparkSMBJoinHintOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSMBJoinHintOptimizer
 
SparkSMBMapJoinInfo - Class in org.apache.hadoop.hive.ql.parse.spark
Data structure to keep track of SMBMapJoin operators during query compilation for Spark.
SparkSMBMapJoinInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.spark.SparkSMBMapJoinInfo
 
SparkSortMergeJoinFactory - Class in org.apache.hadoop.hive.ql.optimizer.spark
Operator factory for Spark SMBJoin processing.
SparkSortMergeJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.spark
Converts a common join operator to an SMB join if eligible.
SparkSortMergeJoinOptimizer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinOptimizer
 
SparkSortMergeJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinOptimizer
 
SparkStageProgress - Class in org.apache.hadoop.hive.ql.exec.spark.status
 
SparkStageProgress(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.spark.status.SparkStageProgress
 
SparkStatistic - Class in org.apache.hadoop.hive.ql.exec.spark.Statistic
 
SparkStatisticGroup - Class in org.apache.hadoop.hive.ql.exec.spark.Statistic
 
SparkStatistics - Class in org.apache.hadoop.hive.ql.exec.spark.Statistic
 
SparkStatisticsBuilder - Class in org.apache.hadoop.hive.ql.exec.spark.Statistic
 
SparkStatisticsBuilder() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.Statistic.SparkStatisticsBuilder
 
SparkTask - Class in org.apache.hadoop.hive.ql.exec.spark
 
SparkTask() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkTask
 
SparkTran<KI extends org.apache.hadoop.io.WritableComparable,VI,KO extends org.apache.hadoop.io.WritableComparable,VO> - Interface in org.apache.hadoop.hive.ql.exec.spark
 
SparkUtilities - Class in org.apache.hadoop.hive.ql.exec.spark
Contains utilities methods used as part of Spark tasks.
SparkUtilities() - Constructor for class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
 
SparkWork - Class in org.apache.hadoop.hive.ql.plan
This class encapsulates all the work objects that can be executed in a single Spark job.
SparkWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.SparkWork
 
SparkWork.Dependency - Class in org.apache.hadoop.hive.ql.plan
 
SparkWork.Dependency() - Constructor for class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
SpecialCases - Class in org.apache.hive.hcatalog.mapreduce
This class is a place to put all the code associated with Special cases.
SpecialCases() - Constructor for class org.apache.hive.hcatalog.mapreduce.SpecialCases
 
specialConstructor - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This variable determines which constructor was used to create this object and thereby affects the semantics of the "getMessage" method (see below).
specialToken - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
specPath - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
specType - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.TableSpec
 
spill() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableConf
Spill one in-memory partition from tail for all previously loaded HybridHashTableContainers.
spillBatchRepeated(VectorizedRowBatch, VectorMapJoinHashTableResult) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
spillBigTableRow(MapJoinTableContainer, Object) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
Postpone processing the big table row temporarily by spilling it to a row container
spillBigTableRow(MapJoinTableContainer, Object) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
spilledMapJoinTables - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
spillHashMapBatch(VectorizedRowBatch, VectorMapJoinHashTableResult[], int[], int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
spillHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
spillHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
spillHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
spillHashMapResultIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
spillPartition(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer
Move the hashtable of a specified partition from memory into local file system
spillPartitionId() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
 
spillReplayBatch - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
spills - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
spills - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
spills - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
spills - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
spillTableDesc - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
split(long) - Method in class org.apache.hadoop.hive.common.DiskRangeList
Splits current element in the list, using DiskRange::slice
split - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
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
split - Variable in class org.apache.hadoop.hive.shims.HadoopShimsSecure.CombineFileRecordReader
 
split(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Split a string using the default separator
split(String, char, char) - Static method in class org.apache.hive.common.util.HiveStringUtils
Split a string using the given separator
split(String, char) - Static method in class org.apache.hive.common.util.HiveStringUtils
Split a string using the given separator, with no escaping performed.
splitAndUnEscape(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Split a string using the default separator/escape character, then unescape the resulting array of strings
splitAndUnEscape(String, char, char) - Static method in class org.apache.hive.common.util.HiveStringUtils
Split a string using the specified separator/escape character, then unescape the resulting array of strings using the same escape/separator.
splitArgs(String) - Static method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
splitCount(HiveJoin) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
splitCount(HiveTableScan) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
splitCount(RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
splitCountRepartition(RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism
 
SplitGrouper - Class in org.apache.hadoop.hive.ql.exec.tez
SplitGrouper is used to combine splits based on head room and locality.
SplitGrouper() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.SplitGrouper
 
splitJoinCondition(List<RelDataTypeField>, RelNode, RelNode, RexNode, List<RexNode>, List<RexNode>, List<Integer>, List<SqlOperator>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelOptUtil
Splits out the equi-join (and optionally, a single non-equi) components of a join condition, and returns what's left.
splitJoinCondition(List<RelDataTypeField>, List<RelNode>, RexNode, List<List<RexNode>>, List<Integer>, List<SqlOperator>) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelOptUtil
Splits out the equi-join (and optionally, a single non-equi) components of a join condition, and returns what's left.
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() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
splitSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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
 
SplitSparkWorkResolver - Class in org.apache.hadoop.hive.ql.optimizer.spark
Do a BFS on the sparkWork graph, and look for any work that has more than one child.
SplitSparkWorkResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.spark.SplitSparkWorkResolver
 
sql(String) - Method in class org.apache.hive.beeline.Commands
 
sql(String, boolean) - Method in class org.apache.hive.beeline.Commands
 
sql11ReservedKeywordsUsedAsCastFunctionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
sql11ReservedKeywordsUsedAsCastFunctionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
sql11ReservedKeywordsUsedAsIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
sql11ReservedKeywordsUsedAsIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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.calcite.translator
 
SqlFunctionConverter() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter
 
SqlFunctionConverter.CalciteUDAF - Class in org.apache.hadoop.hive.ql.optimizer.calcite.translator
 
SqlFunctionConverter.CalciteUDAF(String, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, ImmutableList<RelDataType>, RelDataType) - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter.CalciteUDAF
 
SqlMathUtil - Class in org.apache.hadoop.hive.common.type
This code was based on code from Microsoft's PolyBase.
SQLOperation - Class in org.apache.hive.service.cli.operation
SQLOperation.
SQLOperation(HiveSession, String, Map<String, String>, boolean) - Constructor for class org.apache.hive.service.cli.operation.SQLOperation
 
SQLPrivilegeType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLPrivTypeGrant - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLStdConfOnlyAuthorizerFactory - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Authorization class that can be used from hive cli, so that configuration in cli mode is set appropriately for SQL standards authorization.
SQLStdConfOnlyAuthorizerFactory() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory
 
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, HiveAuthzSessionContext) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
SQLStdHiveAccessControllerWrapper - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Wrapper for SQLStdHiveAccessController that does validation of arguments and then calls the real object.
SQLStdHiveAccessControllerWrapper(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider, HiveAuthzSessionContext) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessControllerWrapper
 
SQLStdHiveAuthorizationValidator - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLStdHiveAuthorizationValidator(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider, SQLStdHiveAccessControllerWrapper, HiveAuthzSessionContext) - 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
 
sqoop(String, String, String, String, String, String, boolean, Boolean) - Method in class org.apache.hive.hcatalog.templeton.Server
Run a Sqoop job.
SQOOP_ARCHIVE_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
SQOOP_HOME_PATH - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
SQOOP_PATH_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
sqoopArchive() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
SqoopDelegator - Class in org.apache.hive.hcatalog.templeton
Submit a Sqoop job.
SqoopDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.SqoopDelegator
 
sqoopHome() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
sqoopPath() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
sqoopVersion() - Method in class org.apache.hive.hcatalog.templeton.Server
Get version of sqoop software being run by this WebHCat server
sqrtAsDouble() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Calculate the square root of this value in double precision.
squareDestructive() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Multiplies this with this, updating this
srcStagingDirProvider - Variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
ss - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
Stage - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
Stage(String) - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.Stage
 
Stage - Class in org.apache.hadoop.hive.ql.plan.api
 
Stage() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
 
Stage(String, StageType, Map<String, String>, Map<String, Long>, List<Task>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
 
Stage(Stage) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
Performs a deep copy on other.
Stage._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
StageType - Enum in org.apache.hadoop.hive.ql.plan.api
 
STAGING_DIR_PATH_FILTER - Static variable in class org.apache.hadoop.hive.common.FileUtils
 
StagingDirectoryProvider - Interface in org.apache.hive.hcatalog.api.repl
Interface for a client to provide a Staging Directory specification
StagingDirectoryProvider.TrivialImpl - Class in org.apache.hive.hcatalog.api.repl
Trivial implementation of this interface - creates
StagingDirectoryProvider.TrivialImpl(String, String) - Constructor for class org.apache.hive.hcatalog.api.repl.StagingDirectoryProvider.TrivialImpl
Trivial implementation of StagingDirectoryProvider which takes a temporary directory and creates directories inside that for each key.
StandardConstantListObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
A StandardListObjectInspector which also implements the ConstantObjectInspector interface.
StandardConstantListObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantListObjectInspector
 
StandardConstantListObjectInspector(ObjectInspector, List<?>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantListObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardConstantMapObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
A StandardMapObjectInspector which also implements the ConstantObjectInspector interface.
StandardConstantMapObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantMapObjectInspector
 
StandardConstantMapObjectInspector(ObjectInspector, ObjectInspector, Map<?, ?>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardConstantMapObjectInspector
Call ObjectInspectorFactory.getStandardMapObjectInspector instead.
StandardListObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
DefaultListObjectInspector works on list data that is stored as a Java List or Java Array object.
StandardListObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
StandardListObjectInspector(ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardMapObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
StandardMapObjectInspector works on map data that is stored as a Java Map object.
StandardMapObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
StandardMapObjectInspector(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
Call ObjectInspectorFactory.getStandardMapObjectInspector instead.
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
 
standardRowInspector - Variable in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
StandardStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
ListStructObjectInspector works on struct data that is stored as a Java List or Java Array object.
StandardStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
StandardStructObjectInspector(List<String>, List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardStructObjectInspector(List<String>, List<ObjectInspector>, List<String>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardStructObjectInspector(List<StructField>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
StandardStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
 
StandardStructObjectInspector.MyField() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
StandardStructObjectInspector.MyField(int, String, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
StandardStructObjectInspector.MyField(int, String, ObjectInspector, String) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
StandardUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
StandardUnionObjectInspector works on union data that is stored as UnionObject.
StandardUnionObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
StandardUnionObjectInspector(List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
StandardUnionObjectInspector.StandardUnion - Class in org.apache.hadoop.hive.serde2.objectinspector
 
StandardUnionObjectInspector.StandardUnion() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
StandardUnionObjectInspector.StandardUnion(byte, Object) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
start() - Method in class org.apache.hadoop.hive.hwi.HWIServer
This method initialized the internal Jetty Servlet Engine.
start() - Method in interface org.apache.hadoop.hive.metastore.MetaStoreThread
Run the thread in the background.
start - Variable in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
start() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter
 
start() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter
 
start() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.Repeated.RepeatedGroupConverter
 
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.
Start() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
start - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadBytesResults
 
start - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
start - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
start - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.StringWrapper
 
start() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
start() - Method in class org.apache.hive.service.AbstractService
Start the service.
start() - Method in class org.apache.hive.service.BreakableService
 
start() - Method in class org.apache.hive.service.cli.CLIService
 
start() - Method in class org.apache.hive.service.cli.operation.OperationManager
 
start() - Method in class org.apache.hive.service.cli.session.SessionManager
 
start() - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
start() - Method in class org.apache.hive.service.CompositeService
 
start() - Method in class org.apache.hive.service.FilterService
 
start() - Method in class org.apache.hive.service.server.HiveServer2
 
start() - Method in interface org.apache.hive.service.Service
Start the service.
start(Service) - Static method in class org.apache.hive.service.ServiceOperations
Start a service.
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.
startCleanup() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
startCleanup(Configuration) - Method in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
startCleanup(Configuration) - Method in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
Start the cleanup process for this storage type.
startCleanup(Configuration) - Method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
startCol - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
startDelegationTokenSecretManager(Configuration, Object, HadoopThriftAuthBridge.Server.ServerMode) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
started - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
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.CommonMergeJoinOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
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
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
startingDateValue - Static variable in class org.apache.hive.common.util.TimestampParser
 
startInstance(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.HDFSCleanup
 
startInstance(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
startJob(Configuration, String, String, String) - Method in class org.apache.hive.hcatalog.templeton.tool.LaunchMapper
 
startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
startMap(TreeMap, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
startMetaStore(int, HadoopThriftAuthBridge) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Start Metastore based on a passed HadoopThriftAuthBridge
startMetaStore(int, HadoopThriftAuthBridge, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Start the metastore store.
startMetaStore(int, HadoopThriftAuthBridge, HiveConf, Lock, Condition, AtomicBoolean) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Start Metastore based on a passed HadoopThriftAuthBridge
startMetaStore(int, HadoopThriftAuthBridge) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
startMetaStore(int, HadoopThriftAuthBridge, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
startMonitor() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.LocalSparkJobMonitor
 
startMonitor() - Method in class org.apache.hadoop.hive.ql.exec.spark.status.RemoteSparkJobMonitor
 
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.
startPartition() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
startPartition() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
startPauseMonitor(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
startPauseMonitor(Configuration) - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
startPauseMonitor(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
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
 
startRecord(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
 
startScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
startServer(String, int) - Method in class org.apache.hadoop.hive.shims.Jetty20SShims
 
startServer(String, int) - Method in class org.apache.hadoop.hive.shims.Jetty23Shims
 
startServer(String, int) - Method in interface org.apache.hadoop.hive.shims.JettyShims
 
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
 
startThreads() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
startTimeHasMethod(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
startTimer(String) - Static method in class org.apache.hadoop.hive.metastore.Deadline
start the timer before a method is invoked.
startTimes - Variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
startupShutdownMessage(Class<?>, String[], Log) - Static method in class org.apache.hive.common.util.HiveStringUtils
Print a log message for starting up and shutting down
startVector(ArrayList, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
startVectorizedBatch(int) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
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.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in class org.apache.hadoop.hive.ql.parse.spark.GenSparkWorkWalker
starting point for walking.
Stat - Class in org.apache.hadoop.hive.ql.exec
 
Stat() - Constructor for class org.apache.hadoop.hive.ql.exec.Stat
 
state - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
stateChanged(Service) - Method in interface org.apache.hive.service.ServiceStateChangeListener
Callback to notify of a state change.
statement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
statement - Variable in exception org.apache.hive.hcatalog.templeton.HcatException
 
statement - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
statement - Variable in class org.apache.hive.service.cli.operation.ExecuteStatementOperation
 
StateProvider - Interface in org.apache.hive.hcatalog.data.transfer.state
If external system wants to communicate any state to slaves, they can do so via this interface.
STATIC_LOG - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
staticFlag - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
statistics - Variable in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
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
 
STATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
STATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
StatObjectConverter - Class in org.apache.hadoop.hive.metastore
This class contains conversion logic that creates Thrift stat objects from JDO stat objects and plain arrays from DirectSQL.
StatObjectConverter() - Constructor for class org.apache.hadoop.hive.metastore.StatObjectConverter
 
stats - Variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDeBase
 
STATS_FILE_PREFIX - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
STATS_GENERATED_VIA_STATS_TASK - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
STATS_TMP_LOC - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
Temp dir for writing stats from tasks.
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.
statsCollectRawDataSize - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
StatsFactory - Class in org.apache.hadoop.hive.ql.stats
A factory of stats publisher and aggregator implementations of the StatsPublisher and StatsAggregator interfaces.
statsFromRecordWriter - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
statsMap - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
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.
statsRequireCompute - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
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.ReduceSinkStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
ReduceSink operator does not change any of the statistics.
StatsRulesProcFactory.ReduceSinkStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.ReduceSinkStatsRule
 
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
 
StatsSetupConst - Class in org.apache.hadoop.hive.common
A class that defines the constant strings used by the statistics implementation.
StatsSetupConst() - Constructor for class org.apache.hadoop.hive.common.StatsSetupConst
 
StatsSetupConst.StatDB - Enum in org.apache.hadoop.hive.common
 
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
 
status - Variable in class org.apache.hive.hcatalog.templeton.CompleteBean
 
status - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
status() - Method in class org.apache.hive.hcatalog.templeton.Server
Check the status of this server.
STATUS_OK - Static variable in class org.apache.hive.hcatalog.templeton.Server
The status message.
StatusDelegator - Class in org.apache.hive.hcatalog.templeton
Fetch the status of a given job id in the queue.
StatusDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.StatusDelegator
 
STATUSDIR_NAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
stderr - Variable in class org.apache.hive.hcatalog.templeton.ExecBean
 
STDERR_FNAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
stdout - Variable in class org.apache.hive.hcatalog.templeton.ExecBean
 
STDOUT_FNAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
stop() - Method in class org.apache.hadoop.hive.hwi.HWIServer
Shut down the running HWI Server.
stop() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
stop() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
stop() - Method in class org.apache.hive.service.AbstractService
Stop the service.
stop() - Method in class org.apache.hive.service.BreakableService
 
stop() - Method in class org.apache.hive.service.cli.CLIService
 
stop() - Method in class org.apache.hive.service.cli.operation.OperationManager
 
stop() - Method in class org.apache.hive.service.cli.session.SessionManager
 
stop() - Method in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
stop() - Method in class org.apache.hive.service.CompositeService
 
stop() - Method in class org.apache.hive.service.FilterService
 
stop() - Method in class org.apache.hive.service.server.HiveServer2
 
stop() - Method in interface org.apache.hive.service.Service
Stop the service.
stop(Service) - Static method in class org.apache.hive.service.ServiceOperations
Stop a service.
stop() - Method in interface org.apache.hive.spark.client.SparkClient
Stops the remote context.
stop() - Static method in class org.apache.hive.spark.client.SparkClientFactory
Stops the SparkClient library.
stopQuietly(Service) - Static method in class org.apache.hive.service.ServiceOperations
Stop a service; if it is null do nothing.
stopThreads() - Method in class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
stopTimer() - Static method in class org.apache.hadoop.hive.metastore.Deadline
end the time after a method is done.
STORAGE_CLASS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
 
storage_root - Variable in class org.apache.hive.hcatalog.templeton.tool.HDFSStorage
 
STORAGE_ROOT - Static variable in interface org.apache.hive.hcatalog.templeton.tool.TempletonStorage
 
storage_root - Variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
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
 
StorageBasedAuthorizationProvider.DropPrivilegeExtractor - Class in org.apache.hadoop.hive.ql.security.authorization
 
StorageBasedAuthorizationProvider.DropPrivilegeExtractor(Privilege[], Privilege[]) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider.DropPrivilegeExtractor
 
StorageDescriptor - Class in org.apache.hadoop.hive.metastore.api
 
StorageDescriptor() - Constructor for class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
StorageDescriptor(List<FieldSchema>, String, String, String, boolean, int, SerDeInfo, List<String>, List<Order>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
StorageDescriptor(StorageDescriptor) - Constructor for class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Performs a deep copy on other.
StorageDescriptor._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StorageFormat - Class in org.apache.hadoop.hive.ql.parse
 
StorageFormat(Configuration) - Constructor for class org.apache.hadoop.hive.ql.parse.StorageFormat
 
StorageFormatDescriptor - Interface in org.apache.hadoop.hive.ql.io
Subclasses represent a storage format for the CREATE TABLE ...
StorageFormatFactory - Class in org.apache.hadoop.hive.ql.io
 
StorageFormatFactory() - Constructor for class org.apache.hadoop.hive.ql.io.StorageFormatFactory
 
storageHandler(String) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
storageHandler(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for StorageHandler class.
storedAs - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.StorageFormatDesc
 
storedAsDirs() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
storedBy - Variable in class org.apache.hive.hcatalog.templeton.TableDesc.StorageFormatDesc
 
StorerInfo - Class in org.apache.hive.hcatalog.mapreduce
Information about the storer to use for writing the data.
StorerInfo(String, String, String, String, Properties) - Constructor for class org.apache.hive.hcatalog.mapreduce.StorerInfo
Initialize the storer information.
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.hive.hcatalog.pig.HCatStorer
 
storesLowerCaseIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storesLowerCaseQuotedIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storesMixedCaseIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storesMixedCaseQuotedIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storesUpperCaseIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storesUpperCaseQuotedIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
storeValue(int, int, BytesWritable, boolean) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
storeValue(int, int, BytesWritable, boolean) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Stores the value for the key in the heap.
stream - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BinaryTreeReader
 
stream - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DoubleTreeReader
 
stream - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.FloatTreeReader
 
stream - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.StringDirectTreeReader
 
STREAMING_JAR_NAME - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
StreamingConnection - Interface in org.apache.hive.hcatalog.streaming
Represents a connection to a HiveEndPoint.
StreamingDelegator - Class in org.apache.hive.hcatalog.templeton
Submit a streaming job to the MapReduce queue.
StreamingDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.StreamingDelegator
 
StreamingException - Exception in org.apache.hive.hcatalog.streaming
 
StreamingException(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.StreamingException
 
StreamingException(String) - Constructor for exception org.apache.hive.hcatalog.streaming.StreamingException
 
StreamingIOFailure - Exception in org.apache.hive.hcatalog.streaming
 
StreamingIOFailure(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.StreamingIOFailure
 
StreamingIOFailure(String) - Constructor for exception org.apache.hive.hcatalog.streaming.StreamingIOFailure
 
streamingJar() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
StreamPrinter - Class in org.apache.hive.common.util
StreamPrinter.
StreamPrinter(InputStream, String, PrintStream) - Constructor for class org.apache.hive.common.util.StreamPrinter
 
STREAMS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
StrictJsonWriter - Class in org.apache.hive.hcatalog.streaming
Streaming Writer handles utf8 encoded Json (Strict syntax).
StrictJsonWriter(HiveEndPoint) - Constructor for class org.apache.hive.hcatalog.streaming.StrictJsonWriter
 
StrictJsonWriter(HiveEndPoint, HiveConf) - Constructor for class org.apache.hive.hcatalog.streaming.StrictJsonWriter
 
StrictRegexWriter - Class in org.apache.hive.hcatalog.streaming
Streaming Writer handles text input data with regex.
StrictRegexWriter(HiveEndPoint) - Constructor for class org.apache.hive.hcatalog.streaming.StrictRegexWriter
 
StrictRegexWriter(HiveEndPoint, HiveConf) - Constructor for class org.apache.hive.hcatalog.streaming.StrictRegexWriter
 
StrictRegexWriter(String, HiveEndPoint, HiveConf) - Constructor for class org.apache.hive.hcatalog.streaming.StrictRegexWriter
 
STRING - Static variable in class org.apache.hive.hcatalog.data.DataType
 
string2long(String) - Static method in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
Convert a string to long.
STRING_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
STRING_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
STRING = 7;
stringArray - Static variable in class org.apache.hive.common.util.TimestampParser
 
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.
StringColumnStatsData - Class in org.apache.hadoop.hive.metastore.api
 
StringColumnStatsData() - Constructor for class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
StringColumnStatsData(long, double, long, long) - Constructor for class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
StringColumnStatsData(StringColumnStatsData) - Constructor for class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
Performs a deep copy on other.
StringColumnStatsData._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StringCompare - Class in org.apache.hadoop.hive.accumulo.predicate.compare
Set of comparison operations over a string constant.
StringCompare() - Constructor for class org.apache.hadoop.hive.accumulo.predicate.compare.StringCompare
 
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
 
stringFor(TimeUnit) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
StringGroupColConcatCharScalar - 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.
StringGroupColConcatCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatCharScalar
 
StringGroupColConcatCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatCharScalar
 
StringGroupColConcatStringScalar - 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.
StringGroupColConcatStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatStringScalar
 
StringGroupColConcatStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatStringScalar
 
StringGroupColConcatVarCharScalar - 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.
StringGroupColConcatVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatVarCharScalar
 
StringGroupColConcatVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupColConcatVarCharScalar
 
StringGroupColEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringGroupColEqualCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualCharScalar
 
StringGroupColEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualCharScalar
 
StringGroupColEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColEqualStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
StringGroupColEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupColumn
 
StringGroupColEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringGroupColEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
StringGroupColEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringGroupColEqualStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringScalar
 
StringGroupColEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringScalar
 
StringGroupColEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringGroupColEqualVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualVarCharScalar
 
StringGroupColEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualVarCharScalar
 
StringGroupColGreaterCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringGroupColGreaterCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterCharScalar
 
StringGroupColGreaterCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterCharScalar
 
StringGroupColGreaterEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringGroupColGreaterEqualCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualCharScalar
 
StringGroupColGreaterEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualCharScalar
 
StringGroupColGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColGreaterEqualStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
StringGroupColGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupColumn
 
StringGroupColGreaterEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringGroupColGreaterEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
StringGroupColGreaterEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringGroupColGreaterEqualStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringScalar
 
StringGroupColGreaterEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringScalar
 
StringGroupColGreaterEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringGroupColGreaterEqualVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualVarCharScalar
 
StringGroupColGreaterEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualVarCharScalar
 
StringGroupColGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColGreaterStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
StringGroupColGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupColumn
 
StringGroupColGreaterStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringGroupColGreaterStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
StringGroupColGreaterStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringGroupColGreaterStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringScalar
 
StringGroupColGreaterStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringScalar
 
StringGroupColGreaterVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringGroupColGreaterVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterVarCharScalar
 
StringGroupColGreaterVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterVarCharScalar
 
StringGroupColLessCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringGroupColLessCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessCharScalar
 
StringGroupColLessCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessCharScalar
 
StringGroupColLessEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringGroupColLessEqualCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualCharScalar
 
StringGroupColLessEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualCharScalar
 
StringGroupColLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColLessEqualStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
StringGroupColLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupColumn
 
StringGroupColLessEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringGroupColLessEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
StringGroupColLessEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringGroupColLessEqualStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringScalar
 
StringGroupColLessEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringScalar
 
StringGroupColLessEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringGroupColLessEqualVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualVarCharScalar
 
StringGroupColLessEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualVarCharScalar
 
StringGroupColLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColLessStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
StringGroupColLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupColumn
 
StringGroupColLessStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringGroupColLessStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
StringGroupColLessStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringGroupColLessStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringScalar
 
StringGroupColLessStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringScalar
 
StringGroupColLessVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringGroupColLessVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessVarCharScalar
 
StringGroupColLessVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessVarCharScalar
 
StringGroupColNotEqualCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringGroupColNotEqualCharScalar(int, HiveChar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualCharScalar
 
StringGroupColNotEqualCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualCharScalar
 
StringGroupColNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Filter the rows in a batch by comparing one string column to another.
StringGroupColNotEqualStringGroupColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
StringGroupColNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupColumn
 
StringGroupColNotEqualStringGroupScalarBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringGroupColNotEqualStringGroupScalarBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
StringGroupColNotEqualStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringGroupColNotEqualStringScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringScalar
 
StringGroupColNotEqualStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringScalar
 
StringGroupColNotEqualVarCharScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringGroupColNotEqualVarCharScalar(int, HiveVarchar, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualVarCharScalar
 
StringGroupColNotEqualVarCharScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualVarCharScalar
 
StringGroupConcatColCol - 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.
StringGroupConcatColCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
StringGroupConcatColCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringGroupConcatColCol
 
StringGroupScalarEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringGroupScalarEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
StringGroupScalarGreaterEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringGroupScalarGreaterEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
StringGroupScalarGreaterStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringGroupScalarGreaterStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
StringGroupScalarLessEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringGroupScalarLessEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
StringGroupScalarLessStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringGroupScalarLessStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
StringGroupScalarNotEqualStringGroupColumnBase - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringGroupScalarNotEqualStringGroupColumnBase() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
StringHex - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
stringifyException(Throwable) - Static method in class org.apache.hive.common.util.HiveStringUtils
Make a string representation of the exception.
stringIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
stringIndices - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
indices of string (byte[]) primitive keys.
stringIndicesIndex - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
StringInitCap - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns str, with the first letter of each word in uppercase, all other letters in lowercase.
StringInitCap(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringInitCap
 
StringInitCap() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringInitCap
 
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
 
StringLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
StringLiteral - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
stringLiteralSequence() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
stringLiteralSequence() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
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
 
StringObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A StringObjectInspector inspects an Object representing a String.
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
 
StringScalarConcatStringGroupCol - 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.
StringScalarConcatStringGroupCol(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringScalarConcatStringGroupCol
 
StringScalarConcatStringGroupCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringScalarConcatStringGroupCol
 
StringScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
StringScalarEqualStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarEqualStringGroupColumn
 
StringScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarEqualStringGroupColumn
 
StringScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
StringScalarGreaterEqualStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterEqualStringGroupColumn
 
StringScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterEqualStringGroupColumn
 
StringScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
StringScalarGreaterStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterStringGroupColumn
 
StringScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarGreaterStringGroupColumn
 
StringScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
StringScalarLessEqualStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessEqualStringGroupColumn
 
StringScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessEqualStringGroupColumn
 
StringScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
StringScalarLessStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessStringGroupColumn
 
StringScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarLessStringGroupColumn
 
StringScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
StringScalarNotEqualStringGroupColumn(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarNotEqualStringGroupColumn
 
StringScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringScalarNotEqualStringGroupColumn
 
STRINGSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
stringStats(StringColumnStatsData) - Static method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
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
 
StringToJobID(String) - Static method in class org.apache.hive.hcatalog.templeton.StatusDelegator
A version of JobID.forName with our app specific error handling.
stringToPath(String[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
stringToURI(String[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
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
 
stringTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
stringTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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
 
stringVal(TStringColumn) - Static method in class org.apache.hive.service.cli.thrift.TColumn
 
stringVal(TStringValue) - Static method in class org.apache.hive.service.cli.thrift.TColumnValue
 
stringValue(String) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
stringValue(String) - Static method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
stringValue(String) - Static method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
stripCode(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
Removes the column encoding code and separator from the original column mapping string.
STRIPE_SIZE - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated.
stripeInformation - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
StripeInformation - Interface in org.apache.hadoop.hive.ql.io.orc
Information about the stripes in an ORC file that is provided by the Reader.
STRIPES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
stripeSize(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Set the stripe size for the file.
stripeStatistics - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader
 
stripeStatistics - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
StripeStatistics - Class in org.apache.hadoop.hive.ql.io.orc
 
STRIPESTATS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
stripHiddenConfigurations(Configuration) - Method in class org.apache.hadoop.hive.conf.HiveConf
Strips hidden config entries from configuration
stripIdentifierQuotes(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
stripQuotePostfix - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
stripQuotePrefix - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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
 
stripSeparatorPrefix - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For quoted fields, strip away the quotes and also need something to strip away the control separator when using complex split method defined here.
stripVirtualColumn(VirtualColumn) - Method in class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
Strip a virtual column out of the set of columns.
Struct() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
STRUCT - Static variable in class org.apache.hive.hcatalog.data.DataType
 
STRUCT_SERIALIZATION_TYPE - Static variable in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
STRUCT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
STRUCT_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
STRUCT = 12;
structEntry(TStructTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
StructField - Interface in org.apache.hadoop.hive.serde2.objectinspector
Classes implementing this interface are considered to represent a field of a struct for this serde package.
structField - Variable in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
StructHBaseValueFactory<T extends HBaseStructValue> - Class in org.apache.hadoop.hive.hbase.struct
Implementation of HBaseValueFactory to consume a custom struct
StructHBaseValueFactory(int, Class<?>) - Constructor for class org.apache.hadoop.hive.hbase.struct.StructHBaseValueFactory
 
structID - Variable in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
StructObject - Interface in org.apache.hadoop.hive.serde2
 
StructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
StructObjectInspector.
StructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
structType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
StructTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
StructTypeInfo represents the TypeInfo of a struct.
StructTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
For java serialization use only.
subAppend(LoggingEvent) - Method in class org.apache.hive.service.cli.operation.LogDivertAppender
Overrides WriterAppender.subAppend(), which does the real logging.
subList(int, int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
submit(DriverContext, SparkWork) - Method in interface org.apache.hadoop.hive.ql.exec.spark.session.SparkSession
Submit given sparkWork to SparkClient.
submit(DriverContext, SparkWork) - Method in class org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl
 
submit(Job<T>) - Method in interface org.apache.hive.spark.client.SparkClient
Submits a job for asynchronous execution.
submitBackgroundOperation(Runnable) - Method in class org.apache.hive.service.cli.session.SessionManager
 
SUBQUERY_TAG_1 - Static variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
SUBQUERY_TAG_2 - Static variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
SubQueryDiagnostic - Class in org.apache.hadoop.hive.ql.parse
 
SubQueryDiagnostic() - Constructor for class org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic
 
SubQueryDiagnostic.QBSubQueryRewrite - Class in org.apache.hadoop.hive.ql.parse
 
SubQueryDiagnostic.QBSubQueryRewriteNoop - Class in org.apache.hadoop.hive.ql.parse
 
subQueryExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
subQueryExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
subQuerySource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
subQuerySource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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(Configuration, String, int) - Method in class org.apache.hadoop.hive.conf.SystemVariables
 
substitute(HiveConf, String) - Method in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
SubStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
SubsetStructObjectInspector implement a wrapper around a base object inspector (baseOI) such that when the row corresponding to the baseOI is given together with this object inspector, it will mask out some fields in the row as if they are not there.
SubStructObjectInspector(StructObjectInspector, int, int) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
Create a new Object Inspector based on a base object inspector and the subset of columns will be inspected (from startCol to startCol+numCols).
subtract(Decimal128, Decimal128, Decimal128, short) - Static method in class org.apache.hadoop.hive.common.type.Decimal128
Calculates subtraction and puts the result into the given object.
subtract(HiveDecimal) - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
subtract(SignedInt128, SignedInt128, SignedInt128) - Static method in class org.apache.hadoop.hive.common.type.SignedInt128
Calculates subtraction and puts the result into the given object.
subtract(Timestamp, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtract(Date, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtract(HiveIntervalYearMonth, HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtract(Timestamp, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtract(HiveIntervalDayTime, HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtract(Timestamp, Timestamp) - Method in class org.apache.hadoop.hive.ql.util.DateTimeMath
 
subtractChecked(int, HiveDecimal, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
subtractChecked(int, HiveDecimalWritable, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
subtractChecked(int, HiveDecimalWritable, HiveDecimal, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
subtractChecked(int, HiveDecimal, HiveDecimalWritable, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
subtractConstructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
This version returns the result as a new object, not modifying the give objects.
subtractDestructive(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Calculates subtraction and stores the result into this object.
subtractDestructive(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Calculates subtraction and stores the result into this object.
subtractDestructive(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Subtracts the given value from this value.
subtractDestructive(int[]) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Subtracts the given value from this value.
SUBTYPES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
suffix - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
SUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
SUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
SUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
SUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
SUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
sumFieldOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
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
 
SunSignalHandler - Class in org.apache.hive.beeline
 
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
 
SUPPORTED_FORMATS - Static variable in class org.apache.hive.hcatalog.templeton.Server
The list of supported return formats.
SUPPORTED_VERSIONS - Static variable in class org.apache.hive.hcatalog.templeton.Server
The list of supported api versions.
supportedStats - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
supportsAcid() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
supportsAcid() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Indicate whether this transaction manager supports ACID operations
supportsAlterTableWithAddColumn() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsAlterTableWithDropColumn() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92EntryLevelSQL() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92FullSQL() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92IntermediateSQL() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsBatchUpdates() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInDataManipulation() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInIndexDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInPrivilegeDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInProcedureCalls() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInTableDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsColumnAliasing() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsConstantObjectInspector(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
supportsConvert() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsConvert(int, int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCoreSQLGrammar() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsCorrelatedSubqueries() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsDataDefinitionAndDataManipulationTransactions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsDataManipulationTransactionsOnly() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsDifferentTableCorrelationNames() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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.
supportsExpressionsInOrderBy() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsExtendedSQLGrammar() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsFullOuterJoins() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsGetGeneratedKeys() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupBy() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupByBeyondSelect() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupByUnrelated() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsIntegrityEnhancementFacility() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
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
 
supportsLikeEscapeClause() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsLimitedOuterJoins() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMinimumSQLGrammar() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMixedCaseIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMixedCaseQuotedIdentifiers() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleOpenResults() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleResultSets() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleTransactions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsNamedParameters() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsNonNullableColumns() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenCursorsAcrossCommit() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenCursorsAcrossRollback() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenStatementsAcrossCommit() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenStatementsAcrossRollback() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOrderByUnrelated() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsOuterJoins() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsPositionedDelete() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsPositionedUpdate() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetConcurrency(int, int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetHoldability(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetType(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSavepoints() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInDataManipulation() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInIndexDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInPrivilegeDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInProcedureCalls() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInTableDefinitions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsScope(PrivilegeScope) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
supportsSelectForUpdate() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsStatementPooling() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsStoredFunctionsUsingCallSyntax() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsStoredProcedures() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInComparisons() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInExists() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInIns() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInQuantifieds() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsTableCorrelationNames() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportStickyBit() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
supportStickyBit() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
supportStickyBit() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
check whether current hadoop supports sticky bit
supportsTransactionIsolationLevel(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsTransactions() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsUnion() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportsUnionAll() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
supportTableLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
supportTrashFeature() - Method in class org.apache.hadoop.hive.shims.Hadoop20SShims
 
supportTrashFeature() - Method in class org.apache.hadoop.hive.shims.Hadoop23Shims
 
supportTrashFeature() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
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
 
switchDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SwitchTo(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Switch to specified lex state.
swizzleFileStatus(FileStatus, boolean) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
swizzleParamPath(Path) - Method in class org.apache.hadoop.fs.ProxyFileSystem
 
symbol - Variable in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
 
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.
synpred10_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred10_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred10_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred10_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred10_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred10_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred11_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred11_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred11_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred11_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred12_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred12_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred12_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred12_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred12_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred12_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred13_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred13_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred13_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred13_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred14_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred14_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred14_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred14_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred15_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred15_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred15_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred15_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred16_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred16_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred1_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred1_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred1_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred1_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred1_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred1_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred1_SelectClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
synpred1_SelectClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
synpred2_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred2_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred2_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred2_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred2_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred2_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred2_SelectClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
synpred2_SelectClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
synpred3_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred3_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred3_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred3_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred3_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred3_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred4_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred4_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred4_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred4_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred4_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred4_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred5_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred5_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred5_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred5_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred5_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred5_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred6_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred6_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred6_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred6_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred6_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred6_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred7_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred7_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred7_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred7_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred7_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred7_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred8_FromClauseParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred8_FromClauseParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
synpred8_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred8_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred8_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred8_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred9_HiveParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred9_HiveParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
synpred9_IdentifiersParser() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
synpred9_IdentifiersParser_fragment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
SyntheticJoinPredicate - Class in org.apache.hadoop.hive.ql.ppd
creates synthetic predicates that represent "IN (keylist other table)"
SyntheticJoinPredicate() - Constructor for class org.apache.hadoop.hive.ql.ppd.SyntheticJoinPredicate
 
SYSENV_HADOOP_TOKEN_FILE_LOCATION - Static variable in class org.apache.hive.hcatalog.common.HCatConstants
 
sysFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
sysFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
SYSTEM_DEFAULT_PRECISION - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
Default precision/scale when system is not able to determine them, such as in case of a non-generic udf.
SYSTEM_DEFAULT_SCALE - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
SYSTEM_PREFIX - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
SystemVariables - Class in org.apache.hadoop.hive.conf
 
SystemVariables() - Constructor for class org.apache.hadoop.hive.conf.SystemVariables
 

T

tabCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
Table - Class in org.apache.hadoop.hive.metastore.api
 
Table() - Constructor for class org.apache.hadoop.hive.metastore.api.Table
 
Table(String, String, String, int, int, int, StorageDescriptor, List<FieldSchema>, Map<String, String>, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.Table
 
Table(Table) - Constructor for class org.apache.hadoop.hive.metastore.api.Table
Performs a deep copy on other.
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
 
table - Variable in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
table - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
Table._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Table.ValidationFailureSemanticException - Exception in org.apache.hadoop.hive.ql.metadata
Marker SemanticException, so that processing that allows for table validation failures and appropriately handles them can recover from these types of SemanticExceptions
Table.ValidationFailureSemanticException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.Table.ValidationFailureSemanticException
 
TABLE_COMMENT - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
TABLE_IS_TRANSACTIONAL - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
TABLE_NAME - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
TABLE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
TABLE_NO_AUTO_COMPACT - Static variable in class org.apache.hadoop.hive.metastore.api.hive_metastoreConstants
 
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 - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
TableAccessInfo - Class in org.apache.hadoop.hive.ql.parse
 
TableAccessInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessInfo
 
tableAlias() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableAlias() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
tableAllColumns() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableAllColumns() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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
 
tableBuckets() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableBucketSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableBucketSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
tableComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableDef - Variable in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
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
 
TableDesc - Class in org.apache.hive.hcatalog.templeton
A description of the table to create.
TableDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc
Create a new TableDesc
TableDesc.ClusteredByDesc - Class in org.apache.hive.hcatalog.templeton
How to cluster the table.
TableDesc.ClusteredByDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
TableDesc.ClusterSortOrderDesc - Class in org.apache.hive.hcatalog.templeton
The clustered sort order.
TableDesc.ClusterSortOrderDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
TableDesc.ClusterSortOrderDesc(String, TableDesc.SortDirectionDesc) - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
TableDesc.RowFormatDesc - Class in org.apache.hive.hcatalog.templeton
The Row Format.
TableDesc.RowFormatDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.RowFormatDesc
 
TableDesc.SerdeDesc - Class in org.apache.hive.hcatalog.templeton
The SERDE Row Format.
TableDesc.SerdeDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.SerdeDesc
 
TableDesc.SortDirectionDesc - Enum in org.apache.hive.hcatalog.templeton
Ther ASC or DESC sort order.
TableDesc.StorageFormatDesc - Class in org.apache.hive.hcatalog.templeton
The storage format.
TableDesc.StorageFormatDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.StorageFormatDesc
 
TableDesc.StoredByDesc - Class in org.apache.hive.hcatalog.templeton
How to store the table.
TableDesc.StoredByDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableDesc.StoredByDesc
 
tableExists(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
tableExists(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated.
tableExists(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
tableExists(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated.
As of release 0.6.0 replaced by IMetaStoreClient.tableExists(String, String). This method will be removed in release 0.7.0.
tableExists(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
 
tableFileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
TableLikeDesc - Class in org.apache.hive.hcatalog.templeton
A description of the table to create that's like another table.
TableLikeDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
tableLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableName - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
tableName - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.TableSpec
 
tableName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
tableName(String) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for TableName.
tableNameColList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableNameColList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
tableNameMapping - Variable in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
tableOrColumn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableOrColumn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
tableOrPartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableOrPartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
tablePartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePartitionPrefix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableProperties(Properties) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Provide the table properties for the table.
tableProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableProperties - Variable in class org.apache.hive.hcatalog.templeton.TableDesc
 
tablePropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePropertiesPrefixed() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TablePropertyDesc - Class in org.apache.hive.hcatalog.templeton
A description of a table property.
TablePropertyDesc() - Constructor for class org.apache.hive.hcatalog.templeton.TablePropertyDesc
 
tableRowFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableRowFormatCollItemsIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableRowFormatFieldIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableRowFormatLinesIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableRowFormatMapKeysIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableRowNullFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tables - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
tables(String) - Method in class org.apache.hive.beeline.Commands
 
tableSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
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(Table) - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanDesc(String, Table) - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanDesc(String, List<VirtualColumn>, Table) - 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
 
TableSchema - Class in org.apache.hive.service.cli
TableSchema.
TableSchema() - Constructor for class org.apache.hive.service.cli.TableSchema
 
TableSchema(int) - Constructor for class org.apache.hive.service.cli.TableSchema
 
TableSchema(TTableSchema) - Constructor for class org.apache.hive.service.cli.TableSchema
 
TableSchema(List<FieldSchema>) - Constructor for class org.apache.hive.service.cli.TableSchema
 
TableSchema(Schema) - Constructor for class org.apache.hive.service.cli.TableSchema
 
TableSizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
TableSizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.TableSizeBasedBigTableSelectorForAutoSMJ
 
tableSkewed() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TableStatsRequest - Class in org.apache.hadoop.hive.metastore.api
 
TableStatsRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
TableStatsRequest(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
TableStatsRequest(TableStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsRequest
Performs a deep copy on other.
TableStatsRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TableStatsResult - Class in org.apache.hadoop.hive.metastore.api
 
TableStatsResult() - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
TableStatsResult(List<ColumnStatisticsObj>) - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
TableStatsResult(TableStatsResult) - Constructor for class org.apache.hadoop.hive.metastore.api.TableStatsResult
Performs a deep copy on other.
TableStatsResult._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TableType - Enum in org.apache.hadoop.hive.metastore
Typesafe enum for types of tables described by the metastore.
tableType(HCatTable.Type) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for table-type.
TableTypeMapping - Interface in org.apache.hive.service.cli.operation
 
TableTypeMappingFactory - Class in org.apache.hive.service.cli.operation
 
TableTypeMappingFactory() - Constructor for class org.apache.hive.service.cli.operation.TableTypeMappingFactory
 
TableTypeMappingFactory.TableTypeMappings - Enum in org.apache.hive.service.cli.operation
 
tabSize - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
tabTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tag - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
tag - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
tagByte - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
tagOrder - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
tagOrder - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
tags - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.UnionTreeReader
 
tar(String, String[], String) - Static method in class org.apache.hadoop.hive.common.CompressionUtils
Archive all the files in the inputFiles into outputFile
TArrayTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TArrayTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
TArrayTypeEntry(int) - Constructor for class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
TArrayTypeEntry(TArrayTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TArrayTypeEntry
Performs a deep copy on other.
TArrayTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
task - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
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 - Class in org.apache.hadoop.hive.ql.plan.api
 
Task() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
 
Task(String, TaskType, Map<String, String>, Map<String, Long>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
 
Task(Task) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
Performs a deep copy on other.
Task._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Task.FeedType - Enum in org.apache.hadoop.hive.ql.exec
 
taskClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.TaskTuple
 
TaskCommitContextRegistry - Class in org.apache.hive.hcatalog.mapreduce
Singleton Registry to track the commit of TaskAttempts.
TaskCommitContextRegistry.TaskCommitterProxy - Interface in org.apache.hive.hcatalog.mapreduce
Implement this interface to register call-backs for committing TaskAttempts.
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
 
taskIdFormat - Static variable in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
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
 
taskName - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
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
 
taskTag - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
taskTmpPath - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
TaskType - Enum in org.apache.hadoop.hive.ql.plan.api
 
taskvec - Static variable in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
TBinaryColumn - Class in org.apache.hive.service.cli.thrift
 
TBinaryColumn() - Constructor for class org.apache.hive.service.cli.thrift.TBinaryColumn
 
TBinaryColumn(List<ByteBuffer>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TBinaryColumn
 
TBinaryColumn(TBinaryColumn) - Constructor for class org.apache.hive.service.cli.thrift.TBinaryColumn
Performs a deep copy on other.
TBinaryColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TBinarySortableProtocol - Class in org.apache.hadoop.hive.serde2.thrift
An implementation of the Thrift Protocol for binary sortable records.
TBinarySortableProtocol(TTransport) - Constructor for class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
TBinarySortableProtocol.Factory - Class in org.apache.hadoop.hive.serde2.thrift
Factory for TBinarySortableProtocol objects.
TBinarySortableProtocol.Factory() - Constructor for class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol.Factory
 
tblProps(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc.Builder
Deprecated.
tblProps(Map<String, String>) - Method in class org.apache.hive.hcatalog.api.HCatTable
Setter for TableProperty map.
TBoolColumn - Class in org.apache.hive.service.cli.thrift
 
TBoolColumn() - Constructor for class org.apache.hive.service.cli.thrift.TBoolColumn
 
TBoolColumn(List<Boolean>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TBoolColumn
 
TBoolColumn(TBoolColumn) - Constructor for class org.apache.hive.service.cli.thrift.TBoolColumn
Performs a deep copy on other.
TBoolColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TBoolValue - Class in org.apache.hive.service.cli.thrift
 
TBoolValue() - Constructor for class org.apache.hive.service.cli.thrift.TBoolValue
 
TBoolValue(TBoolValue) - Constructor for class org.apache.hive.service.cli.thrift.TBoolValue
Performs a deep copy on other.
TBoolValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TByteColumn - Class in org.apache.hive.service.cli.thrift
 
TByteColumn() - Constructor for class org.apache.hive.service.cli.thrift.TByteColumn
 
TByteColumn(List<Byte>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TByteColumn
 
TByteColumn(TByteColumn) - Constructor for class org.apache.hive.service.cli.thrift.TByteColumn
Performs a deep copy on other.
TByteColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TByteValue - Class in org.apache.hive.service.cli.thrift
 
TByteValue() - Constructor for class org.apache.hive.service.cli.thrift.TByteValue
 
TByteValue(TByteValue) - Constructor for class org.apache.hive.service.cli.thrift.TByteValue
Performs a deep copy on other.
TByteValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCancelDelegationTokenReq - Class in org.apache.hive.service.cli.thrift
 
TCancelDelegationTokenReq() - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
TCancelDelegationTokenReq(TSessionHandle, String) - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
TCancelDelegationTokenReq(TCancelDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
Performs a deep copy on other.
TCancelDelegationTokenReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCancelDelegationTokenResp - Class in org.apache.hive.service.cli.thrift
 
TCancelDelegationTokenResp() - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
TCancelDelegationTokenResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
TCancelDelegationTokenResp(TCancelDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
Performs a deep copy on other.
TCancelDelegationTokenResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCancelOperationReq - Class in org.apache.hive.service.cli.thrift
 
TCancelOperationReq() - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
TCancelOperationReq(TOperationHandle) - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
TCancelOperationReq(TCancelOperationReq) - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationReq
Performs a deep copy on other.
TCancelOperationReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCancelOperationResp - Class in org.apache.hive.service.cli.thrift
 
TCancelOperationResp() - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
TCancelOperationResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
TCancelOperationResp(TCancelOperationResp) - Constructor for class org.apache.hive.service.cli.thrift.TCancelOperationResp
Performs a deep copy on other.
TCancelOperationResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService - Class in org.apache.hive.service.cli.thrift
 
TCLIService() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService
 
TCLIService.AsyncClient - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient
 
TCLIService.AsyncClient.CancelDelegationToken_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.CancelDelegationToken_call(TCancelDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelDelegationToken_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelDelegationToken_call
 
TCLIService.AsyncClient.CancelOperation_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.CancelOperation_call(TCancelOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CancelOperation_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelOperation_call
 
TCLIService.AsyncClient.CloseOperation_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.CloseOperation_call(TCloseOperationReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseOperation_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseOperation_call
 
TCLIService.AsyncClient.CloseSession_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.CloseSession_call(TCloseSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.CloseSession_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseSession_call
 
TCLIService.AsyncClient.ExecuteStatement_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.ExecuteStatement_call(TExecuteStatementReq, AsyncMethodCallback<TCLIService.AsyncClient.ExecuteStatement_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.ExecuteStatement_call
 
TCLIService.AsyncClient.Factory - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.Factory
 
TCLIService.AsyncClient.FetchResults_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.FetchResults_call(TFetchResultsReq, AsyncMethodCallback<TCLIService.AsyncClient.FetchResults_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.FetchResults_call
 
TCLIService.AsyncClient.GetCatalogs_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetCatalogs_call(TGetCatalogsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetCatalogs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetCatalogs_call
 
TCLIService.AsyncClient.GetColumns_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetColumns_call(TGetColumnsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetColumns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetColumns_call
 
TCLIService.AsyncClient.GetDelegationToken_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetDelegationToken_call(TGetDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.GetDelegationToken_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetDelegationToken_call
 
TCLIService.AsyncClient.GetFunctions_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetFunctions_call(TGetFunctionsReq, AsyncMethodCallback<TCLIService.AsyncClient.GetFunctions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetFunctions_call
 
TCLIService.AsyncClient.GetInfo_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetInfo_call(TGetInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetInfo_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetInfo_call
 
TCLIService.AsyncClient.GetOperationStatus_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetOperationStatus_call(TGetOperationStatusReq, AsyncMethodCallback<TCLIService.AsyncClient.GetOperationStatus_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetOperationStatus_call
 
TCLIService.AsyncClient.GetResultSetMetadata_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetResultSetMetadata_call(TGetResultSetMetadataReq, AsyncMethodCallback<TCLIService.AsyncClient.GetResultSetMetadata_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetResultSetMetadata_call
 
TCLIService.AsyncClient.GetSchemas_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetSchemas_call(TGetSchemasReq, AsyncMethodCallback<TCLIService.AsyncClient.GetSchemas_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetSchemas_call
 
TCLIService.AsyncClient.GetTables_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetTables_call(TGetTablesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTables_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTables_call
 
TCLIService.AsyncClient.GetTableTypes_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetTableTypes_call(TGetTableTypesReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTableTypes_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTableTypes_call
 
TCLIService.AsyncClient.GetTypeInfo_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.GetTypeInfo_call(TGetTypeInfoReq, AsyncMethodCallback<TCLIService.AsyncClient.GetTypeInfo_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTypeInfo_call
 
TCLIService.AsyncClient.OpenSession_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.OpenSession_call(TOpenSessionReq, AsyncMethodCallback<TCLIService.AsyncClient.OpenSession_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.OpenSession_call
 
TCLIService.AsyncClient.RenewDelegationToken_call - Class in org.apache.hive.service.cli.thrift
 
TCLIService.AsyncClient.RenewDelegationToken_call(TRenewDelegationTokenReq, AsyncMethodCallback<TCLIService.AsyncClient.RenewDelegationToken_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.RenewDelegationToken_call
 
TCLIService.AsyncIface - Interface in org.apache.hive.service.cli.thrift
 
TCLIService.CancelDelegationToken_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CancelDelegationToken_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
TCLIService.CancelDelegationToken_args(TCancelDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
TCLIService.CancelDelegationToken_args(TCLIService.CancelDelegationToken_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
Performs a deep copy on other.
TCLIService.CancelDelegationToken_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CancelDelegationToken_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CancelDelegationToken_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
TCLIService.CancelDelegationToken_result(TCancelDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
TCLIService.CancelDelegationToken_result(TCLIService.CancelDelegationToken_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
Performs a deep copy on other.
TCLIService.CancelDelegationToken_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CancelOperation_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CancelOperation_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
TCLIService.CancelOperation_args(TCancelOperationReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
TCLIService.CancelOperation_args(TCLIService.CancelOperation_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
Performs a deep copy on other.
TCLIService.CancelOperation_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CancelOperation_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CancelOperation_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
TCLIService.CancelOperation_result(TCancelOperationResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
TCLIService.CancelOperation_result(TCLIService.CancelOperation_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
Performs a deep copy on other.
TCLIService.CancelOperation_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.Client - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Client(TProtocol) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Client
 
TCLIService.Client(TProtocol, TProtocol) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Client
 
TCLIService.Client.Factory - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Client.Factory() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Client.Factory
 
TCLIService.CloseOperation_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CloseOperation_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
TCLIService.CloseOperation_args(TCloseOperationReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
TCLIService.CloseOperation_args(TCLIService.CloseOperation_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
Performs a deep copy on other.
TCLIService.CloseOperation_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CloseOperation_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CloseOperation_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
TCLIService.CloseOperation_result(TCloseOperationResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
TCLIService.CloseOperation_result(TCLIService.CloseOperation_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
Performs a deep copy on other.
TCLIService.CloseOperation_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CloseSession_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CloseSession_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
TCLIService.CloseSession_args(TCloseSessionReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
TCLIService.CloseSession_args(TCLIService.CloseSession_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
Performs a deep copy on other.
TCLIService.CloseSession_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.CloseSession_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.CloseSession_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
TCLIService.CloseSession_result(TCloseSessionResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
TCLIService.CloseSession_result(TCLIService.CloseSession_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
Performs a deep copy on other.
TCLIService.CloseSession_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.ExecuteStatement_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.ExecuteStatement_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
TCLIService.ExecuteStatement_args(TExecuteStatementReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
TCLIService.ExecuteStatement_args(TCLIService.ExecuteStatement_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
Performs a deep copy on other.
TCLIService.ExecuteStatement_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.ExecuteStatement_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.ExecuteStatement_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
TCLIService.ExecuteStatement_result(TExecuteStatementResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
TCLIService.ExecuteStatement_result(TCLIService.ExecuteStatement_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
Performs a deep copy on other.
TCLIService.ExecuteStatement_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.FetchResults_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.FetchResults_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
TCLIService.FetchResults_args(TFetchResultsReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
TCLIService.FetchResults_args(TCLIService.FetchResults_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
Performs a deep copy on other.
TCLIService.FetchResults_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.FetchResults_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.FetchResults_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
TCLIService.FetchResults_result(TFetchResultsResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
TCLIService.FetchResults_result(TCLIService.FetchResults_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
Performs a deep copy on other.
TCLIService.FetchResults_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetCatalogs_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetCatalogs_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
TCLIService.GetCatalogs_args(TGetCatalogsReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
TCLIService.GetCatalogs_args(TCLIService.GetCatalogs_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
Performs a deep copy on other.
TCLIService.GetCatalogs_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetCatalogs_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetCatalogs_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
TCLIService.GetCatalogs_result(TGetCatalogsResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
TCLIService.GetCatalogs_result(TCLIService.GetCatalogs_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
Performs a deep copy on other.
TCLIService.GetCatalogs_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetColumns_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetColumns_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
TCLIService.GetColumns_args(TGetColumnsReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
TCLIService.GetColumns_args(TCLIService.GetColumns_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
Performs a deep copy on other.
TCLIService.GetColumns_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetColumns_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetColumns_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
TCLIService.GetColumns_result(TGetColumnsResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
TCLIService.GetColumns_result(TCLIService.GetColumns_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
Performs a deep copy on other.
TCLIService.GetColumns_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetDelegationToken_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetDelegationToken_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
TCLIService.GetDelegationToken_args(TGetDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
TCLIService.GetDelegationToken_args(TCLIService.GetDelegationToken_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
Performs a deep copy on other.
TCLIService.GetDelegationToken_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetDelegationToken_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetDelegationToken_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
TCLIService.GetDelegationToken_result(TGetDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
TCLIService.GetDelegationToken_result(TCLIService.GetDelegationToken_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
Performs a deep copy on other.
TCLIService.GetDelegationToken_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetFunctions_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetFunctions_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
TCLIService.GetFunctions_args(TGetFunctionsReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
TCLIService.GetFunctions_args(TCLIService.GetFunctions_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
Performs a deep copy on other.
TCLIService.GetFunctions_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetFunctions_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetFunctions_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
TCLIService.GetFunctions_result(TGetFunctionsResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
TCLIService.GetFunctions_result(TCLIService.GetFunctions_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
Performs a deep copy on other.
TCLIService.GetFunctions_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetInfo_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetInfo_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
TCLIService.GetInfo_args(TGetInfoReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
TCLIService.GetInfo_args(TCLIService.GetInfo_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
Performs a deep copy on other.
TCLIService.GetInfo_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetInfo_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetInfo_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
TCLIService.GetInfo_result(TGetInfoResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
TCLIService.GetInfo_result(TCLIService.GetInfo_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
Performs a deep copy on other.
TCLIService.GetInfo_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetOperationStatus_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetOperationStatus_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
TCLIService.GetOperationStatus_args(TGetOperationStatusReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
TCLIService.GetOperationStatus_args(TCLIService.GetOperationStatus_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
Performs a deep copy on other.
TCLIService.GetOperationStatus_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetOperationStatus_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetOperationStatus_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
TCLIService.GetOperationStatus_result(TGetOperationStatusResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
TCLIService.GetOperationStatus_result(TCLIService.GetOperationStatus_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
Performs a deep copy on other.
TCLIService.GetOperationStatus_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetResultSetMetadata_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetResultSetMetadata_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
TCLIService.GetResultSetMetadata_args(TGetResultSetMetadataReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
TCLIService.GetResultSetMetadata_args(TCLIService.GetResultSetMetadata_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
Performs a deep copy on other.
TCLIService.GetResultSetMetadata_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetResultSetMetadata_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetResultSetMetadata_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
TCLIService.GetResultSetMetadata_result(TGetResultSetMetadataResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
TCLIService.GetResultSetMetadata_result(TCLIService.GetResultSetMetadata_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
Performs a deep copy on other.
TCLIService.GetResultSetMetadata_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetSchemas_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetSchemas_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
TCLIService.GetSchemas_args(TGetSchemasReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
TCLIService.GetSchemas_args(TCLIService.GetSchemas_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
Performs a deep copy on other.
TCLIService.GetSchemas_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetSchemas_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetSchemas_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
TCLIService.GetSchemas_result(TGetSchemasResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
TCLIService.GetSchemas_result(TCLIService.GetSchemas_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
Performs a deep copy on other.
TCLIService.GetSchemas_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTables_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTables_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
TCLIService.GetTables_args(TGetTablesReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
TCLIService.GetTables_args(TCLIService.GetTables_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
Performs a deep copy on other.
TCLIService.GetTables_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTables_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTables_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
TCLIService.GetTables_result(TGetTablesResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
TCLIService.GetTables_result(TCLIService.GetTables_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
Performs a deep copy on other.
TCLIService.GetTables_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTableTypes_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTableTypes_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
TCLIService.GetTableTypes_args(TGetTableTypesReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
TCLIService.GetTableTypes_args(TCLIService.GetTableTypes_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
Performs a deep copy on other.
TCLIService.GetTableTypes_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTableTypes_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTableTypes_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
TCLIService.GetTableTypes_result(TGetTableTypesResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
TCLIService.GetTableTypes_result(TCLIService.GetTableTypes_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
Performs a deep copy on other.
TCLIService.GetTableTypes_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTypeInfo_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTypeInfo_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
TCLIService.GetTypeInfo_args(TGetTypeInfoReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
TCLIService.GetTypeInfo_args(TCLIService.GetTypeInfo_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
Performs a deep copy on other.
TCLIService.GetTypeInfo_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.GetTypeInfo_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.GetTypeInfo_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
TCLIService.GetTypeInfo_result(TGetTypeInfoResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
TCLIService.GetTypeInfo_result(TCLIService.GetTypeInfo_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
Performs a deep copy on other.
TCLIService.GetTypeInfo_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.Iface - Interface in org.apache.hive.service.cli.thrift
 
TCLIService.OpenSession_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.OpenSession_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
TCLIService.OpenSession_args(TOpenSessionReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
TCLIService.OpenSession_args(TCLIService.OpenSession_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
Performs a deep copy on other.
TCLIService.OpenSession_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.OpenSession_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.OpenSession_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
TCLIService.OpenSession_result(TOpenSessionResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
TCLIService.OpenSession_result(TCLIService.OpenSession_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
Performs a deep copy on other.
TCLIService.OpenSession_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.Processor<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor(I) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor
 
TCLIService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor
 
TCLIService.Processor.CancelDelegationToken<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.CancelDelegationToken() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelDelegationToken
 
TCLIService.Processor.CancelOperation<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.CancelOperation() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.CancelOperation
 
TCLIService.Processor.CloseOperation<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.CloseOperation() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseOperation
 
TCLIService.Processor.CloseSession<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.CloseSession() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.CloseSession
 
TCLIService.Processor.ExecuteStatement<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.ExecuteStatement() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.ExecuteStatement
 
TCLIService.Processor.FetchResults<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.FetchResults() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.FetchResults
 
TCLIService.Processor.GetCatalogs<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetCatalogs() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetCatalogs
 
TCLIService.Processor.GetColumns<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetColumns() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetColumns
 
TCLIService.Processor.GetDelegationToken<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetDelegationToken() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetDelegationToken
 
TCLIService.Processor.GetFunctions<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetFunctions() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetFunctions
 
TCLIService.Processor.GetInfo<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetInfo() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetInfo
 
TCLIService.Processor.GetOperationStatus<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetOperationStatus() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetOperationStatus
 
TCLIService.Processor.GetResultSetMetadata<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetResultSetMetadata() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetResultSetMetadata
 
TCLIService.Processor.GetSchemas<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetSchemas() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetSchemas
 
TCLIService.Processor.GetTables<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetTables() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTables
 
TCLIService.Processor.GetTableTypes<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetTableTypes() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTableTypes
 
TCLIService.Processor.GetTypeInfo<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.GetTypeInfo() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.GetTypeInfo
 
TCLIService.Processor.OpenSession<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.OpenSession() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.OpenSession
 
TCLIService.Processor.RenewDelegationToken<I extends TCLIService.Iface> - Class in org.apache.hive.service.cli.thrift
 
TCLIService.Processor.RenewDelegationToken() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.Processor.RenewDelegationToken
 
TCLIService.RenewDelegationToken_args - Class in org.apache.hive.service.cli.thrift
 
TCLIService.RenewDelegationToken_args() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
TCLIService.RenewDelegationToken_args(TRenewDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
TCLIService.RenewDelegationToken_args(TCLIService.RenewDelegationToken_args) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
Performs a deep copy on other.
TCLIService.RenewDelegationToken_args._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIService.RenewDelegationToken_result - Class in org.apache.hive.service.cli.thrift
 
TCLIService.RenewDelegationToken_result() - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
TCLIService.RenewDelegationToken_result(TRenewDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
TCLIService.RenewDelegationToken_result(TCLIService.RenewDelegationToken_result) - Constructor for class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
Performs a deep copy on other.
TCLIService.RenewDelegationToken_result._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCLIServiceConstants - Class in org.apache.hive.service.cli.thrift
 
TCLIServiceConstants() - Constructor for class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
TCloseOperationReq - Class in org.apache.hive.service.cli.thrift
 
TCloseOperationReq() - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
TCloseOperationReq(TOperationHandle) - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
TCloseOperationReq(TCloseOperationReq) - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationReq
Performs a deep copy on other.
TCloseOperationReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCloseOperationResp - Class in org.apache.hive.service.cli.thrift
 
TCloseOperationResp() - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
TCloseOperationResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
TCloseOperationResp(TCloseOperationResp) - Constructor for class org.apache.hive.service.cli.thrift.TCloseOperationResp
Performs a deep copy on other.
TCloseOperationResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCloseSessionReq - Class in org.apache.hive.service.cli.thrift
 
TCloseSessionReq() - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
TCloseSessionReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
TCloseSessionReq(TCloseSessionReq) - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionReq
Performs a deep copy on other.
TCloseSessionReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCloseSessionResp - Class in org.apache.hive.service.cli.thrift
 
TCloseSessionResp() - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
TCloseSessionResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
TCloseSessionResp(TCloseSessionResp) - Constructor for class org.apache.hive.service.cli.thrift.TCloseSessionResp
Performs a deep copy on other.
TCloseSessionResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumn - Class in org.apache.hive.service.cli.thrift
 
TColumn() - Constructor for class org.apache.hive.service.cli.thrift.TColumn
 
TColumn(TColumn._Fields, Object) - Constructor for class org.apache.hive.service.cli.thrift.TColumn
 
TColumn(TColumn) - Constructor for class org.apache.hive.service.cli.thrift.TColumn
 
TColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumnDesc - Class in org.apache.hive.service.cli.thrift
 
TColumnDesc() - Constructor for class org.apache.hive.service.cli.thrift.TColumnDesc
 
TColumnDesc(String, TTypeDesc, int) - Constructor for class org.apache.hive.service.cli.thrift.TColumnDesc
 
TColumnDesc(TColumnDesc) - Constructor for class org.apache.hive.service.cli.thrift.TColumnDesc
Performs a deep copy on other.
TColumnDesc._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumnValue - Class in org.apache.hive.service.cli.thrift
 
TColumnValue() - Constructor for class org.apache.hive.service.cli.thrift.TColumnValue
 
TColumnValue(TColumnValue._Fields, Object) - Constructor for class org.apache.hive.service.cli.thrift.TColumnValue
 
TColumnValue(TColumnValue) - Constructor for class org.apache.hive.service.cli.thrift.TColumnValue
 
TColumnValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCTLSeparatedProtocol - Class in org.apache.hadoop.hive.serde2.thrift
An implementation of the Thrift Protocol for ctl separated records.
TCTLSeparatedProtocol(TTransport) - Constructor for class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The simple constructor which assumes ctl-a, ctl-b and '\n' separators and to return empty strings for empty fields.
TCTLSeparatedProtocol(TTransport, int) - Constructor for class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
TCTLSeparatedProtocol(TTransport, String, String, String, String, boolean, int) - Constructor for class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
TCTLSeparatedProtocol.Factory - Class in org.apache.hadoop.hive.serde2.thrift
Factory for JSON protocol objects.
TCTLSeparatedProtocol.Factory() - Constructor for class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol.Factory
 
TDoubleColumn - Class in org.apache.hive.service.cli.thrift
 
TDoubleColumn() - Constructor for class org.apache.hive.service.cli.thrift.TDoubleColumn
 
TDoubleColumn(List<Double>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TDoubleColumn
 
TDoubleColumn(TDoubleColumn) - Constructor for class org.apache.hive.service.cli.thrift.TDoubleColumn
Performs a deep copy on other.
TDoubleColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TDoubleValue - Class in org.apache.hive.service.cli.thrift
 
TDoubleValue() - Constructor for class org.apache.hive.service.cli.thrift.TDoubleValue
 
TDoubleValue(TDoubleValue) - Constructor for class org.apache.hive.service.cli.thrift.TDoubleValue
Performs a deep copy on other.
TDoubleValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tell() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Return the current position.
temp - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToString
 
TEMP_DIR_NAME - Static variable in class org.apache.hive.hcatalog.mapreduce.FosterStorageHandler
The directory under which data is initially written for a non partitioned table
TEMPLETON_CONF_FILENAMES - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
TEMPLETON_CONTROLLER_MR_AM_JAVA_OPTS - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
TEMPLETON_CONTROLLER_MR_CHILD_OPTS - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
TEMPLETON_HOME_VAR - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
TEMPLETON_JOB_LAUNCH_TIME_NAME - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
TempletonControllerJob - Class in org.apache.hive.hcatalog.templeton.tool
A Map Reduce job that will start another job.
TempletonControllerJob(boolean, AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.tool.TempletonControllerJob
 
TempletonDelegator - Class in org.apache.hive.hcatalog.templeton
The helper class for all the Templeton delegator classes.
TempletonDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.TempletonDelegator
 
TempletonStorage - Interface in org.apache.hive.hcatalog.templeton.tool
An interface to handle different Templeton storage methods, including ZooKeeper and HDFS.
TempletonStorage.Type - Enum in org.apache.hive.hcatalog.templeton.tool
 
TempletonUtils - Class in org.apache.hive.hcatalog.templeton.tool
General utility methods.
TempletonUtils() - Constructor for class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
TemporaryHashSinkOperator - Class in org.apache.hadoop.hive.ql.exec
 
TemporaryHashSinkOperator(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.TemporaryHashSinkOperator
 
TEN_TO_THIRTYEIGHT - Static variable in class org.apache.hadoop.hive.common.type.UnsignedInt128
A special value representing 10**38.
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() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
Terminates the aggregation and return the final result.
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
Terminates the aggregation and return the final result.
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Terminates the max N lookup and return the final result.
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
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.GenericUDAFNumericStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator.SumAvgEnhancer
 
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() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
Terminate a partial aggregation and return the state.
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
Terminate a partial aggregation and return the state.
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
Get partial aggregation results.
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
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.GenericUDAFNumericStatsEvaluator
 
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.GenericUDAFAbstractRankEvaluator
 
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.GenericUDAFStreamingEvaluator
 
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
 
test - Static variable in class org.apache.hadoop.hive.cli.RCFileCat
 
test(byte[]) - Method in class org.apache.hive.common.util.BloomFilter
 
testAndCreateConnection() - Method in class org.apache.hive.hcatalog.listener.NotificationListener
Does a health check on the connection by sending a dummy message.
testBytes(byte[], int) - Method in class org.apache.hive.common.util.BloomFilter
 
testDouble(double) - Method in class org.apache.hive.common.util.BloomFilter
 
testLong(long) - Method in class org.apache.hive.common.util.BloomFilter
 
testString(String) - Method in class org.apache.hive.common.util.BloomFilter
 
TExecuteStatementReq - Class in org.apache.hive.service.cli.thrift
 
TExecuteStatementReq() - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
TExecuteStatementReq(TSessionHandle, String) - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
TExecuteStatementReq(TExecuteStatementReq) - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementReq
Performs a deep copy on other.
TExecuteStatementReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TExecuteStatementResp - Class in org.apache.hive.service.cli.thrift
 
TExecuteStatementResp() - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
TExecuteStatementResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
TExecuteStatementResp(TExecuteStatementResp) - Constructor for class org.apache.hive.service.cli.thrift.TExecuteStatementResp
Performs a deep copy on other.
TExecuteStatementResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TEXTFILE - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
TEXTFILE_INPUT - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
TEXTFILE_OUTPUT - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
TextFileStorageFormatDescriptor - Class in org.apache.hadoop.hive.ql.io
 
TextFileStorageFormatDescriptor() - Constructor for class org.apache.hadoop.hive.ql.io.TextFileStorageFormatDescriptor
 
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_COMPLETE - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
Hive on Tez produces progress report that looks like this Map 1: -/- Reducer 2: 0/1 Map 1: -/- Reducer 2: 0(+1)/1 Map 1: -/- Reducer 2: 1/1 -/- means there are no tasks (yet) 0/1 means 1 total tasks, 0 completed 1(+2)/3 means 3 total, 1 completed and 2 running HIVE-8495, in particular https://issues.apache.org/jira/secure/attachment/12675504/Screen%20Shot%202014-10-16%20at%209.35.26%20PM.png has more examples.
TEZ_COUNTERS - Static variable in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
 
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_MERGE_CURRENT_MERGE_FILE_PREFIX - Static variable in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
TEZ_MERGE_WORK_FILE_PREFIXES - Static variable in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
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
 
TEZ_TMP_DIR_KEY - Static variable in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
TezBucketJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
TezBucketJoinProcCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
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
 
TezDummyStoreOperator - Class in org.apache.hadoop.hive.ql.exec
A dummy store operator same as the dummy store operator but for tez.
TezDummyStoreOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.TezDummyStoreOperator
 
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(HiveConf, TezEdgeProperty.EdgeType, boolean, int, int, long) - 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
 
TezJobExecHelper - Class in org.apache.hadoop.hive.ql.exec.tez
TezJobExecHelper is a utility to safely call Tez functionality from common code paths.
TezJobExecHelper() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezJobExecHelper
 
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
 
TezJsonParser - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
TezJsonParser() - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParser
 
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(MergedInputContext, List<Input>) - 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(ProcessorContext) - 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.
TezSessionPoolManager() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
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
 
TezWork.VertexType - Enum in org.apache.hadoop.hive.ql.plan
 
TFetchOrientation - Enum in org.apache.hive.service.cli.thrift
 
TFetchResultsReq - Class in org.apache.hive.service.cli.thrift
 
TFetchResultsReq() - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
TFetchResultsReq(TOperationHandle, TFetchOrientation, long) - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
TFetchResultsReq(TFetchResultsReq) - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsReq
Performs a deep copy on other.
TFetchResultsReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TFetchResultsResp - Class in org.apache.hive.service.cli.thrift
 
TFetchResultsResp() - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
TFetchResultsResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
TFetchResultsResp(TFetchResultsResp) - Constructor for class org.apache.hive.service.cli.thrift.TFetchResultsResp
Performs a deep copy on other.
TFetchResultsResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TFilterTransport - Class in org.apache.hadoop.hive.thrift
Transport that simply wraps another transport.
TFilterTransport(TTransport) - Constructor for class org.apache.hadoop.hive.thrift.TFilterTransport
 
TGetCatalogsReq - Class in org.apache.hive.service.cli.thrift
 
TGetCatalogsReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
TGetCatalogsReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
TGetCatalogsReq(TGetCatalogsReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsReq
Performs a deep copy on other.
TGetCatalogsReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetCatalogsResp - Class in org.apache.hive.service.cli.thrift
 
TGetCatalogsResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
TGetCatalogsResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
TGetCatalogsResp(TGetCatalogsResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetCatalogsResp
Performs a deep copy on other.
TGetCatalogsResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetColumnsReq - Class in org.apache.hive.service.cli.thrift
 
TGetColumnsReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
TGetColumnsReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
TGetColumnsReq(TGetColumnsReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsReq
Performs a deep copy on other.
TGetColumnsReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetColumnsResp - Class in org.apache.hive.service.cli.thrift
 
TGetColumnsResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
TGetColumnsResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
TGetColumnsResp(TGetColumnsResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetColumnsResp
Performs a deep copy on other.
TGetColumnsResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetDelegationTokenReq - Class in org.apache.hive.service.cli.thrift
 
TGetDelegationTokenReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
TGetDelegationTokenReq(TSessionHandle, String, String) - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
TGetDelegationTokenReq(TGetDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
Performs a deep copy on other.
TGetDelegationTokenReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetDelegationTokenResp - Class in org.apache.hive.service.cli.thrift
 
TGetDelegationTokenResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
TGetDelegationTokenResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
TGetDelegationTokenResp(TGetDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
Performs a deep copy on other.
TGetDelegationTokenResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetFunctionsReq - Class in org.apache.hive.service.cli.thrift
 
TGetFunctionsReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
TGetFunctionsReq(TSessionHandle, String) - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
TGetFunctionsReq(TGetFunctionsReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsReq
Performs a deep copy on other.
TGetFunctionsReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetFunctionsResp - Class in org.apache.hive.service.cli.thrift
 
TGetFunctionsResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
TGetFunctionsResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
TGetFunctionsResp(TGetFunctionsResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetFunctionsResp
Performs a deep copy on other.
TGetFunctionsResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetInfoReq - Class in org.apache.hive.service.cli.thrift
 
TGetInfoReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoReq
 
TGetInfoReq(TSessionHandle, TGetInfoType) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoReq
 
TGetInfoReq(TGetInfoReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoReq
Performs a deep copy on other.
TGetInfoReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetInfoResp - Class in org.apache.hive.service.cli.thrift
 
TGetInfoResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoResp
 
TGetInfoResp(TStatus, TGetInfoValue) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoResp
 
TGetInfoResp(TGetInfoResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoResp
Performs a deep copy on other.
TGetInfoResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetInfoType - Enum in org.apache.hive.service.cli.thrift
 
TGetInfoValue - Class in org.apache.hive.service.cli.thrift
 
TGetInfoValue() - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoValue
 
TGetInfoValue(TGetInfoValue._Fields, Object) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoValue
 
TGetInfoValue(TGetInfoValue) - Constructor for class org.apache.hive.service.cli.thrift.TGetInfoValue
 
TGetInfoValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetOperationStatusReq - Class in org.apache.hive.service.cli.thrift
 
TGetOperationStatusReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
TGetOperationStatusReq(TOperationHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
TGetOperationStatusReq(TGetOperationStatusReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
Performs a deep copy on other.
TGetOperationStatusReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetOperationStatusResp - Class in org.apache.hive.service.cli.thrift
 
TGetOperationStatusResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
TGetOperationStatusResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
TGetOperationStatusResp(TGetOperationStatusResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
Performs a deep copy on other.
TGetOperationStatusResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetResultSetMetadataReq - Class in org.apache.hive.service.cli.thrift
 
TGetResultSetMetadataReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
TGetResultSetMetadataReq(TOperationHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
TGetResultSetMetadataReq(TGetResultSetMetadataReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
Performs a deep copy on other.
TGetResultSetMetadataReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetResultSetMetadataResp - Class in org.apache.hive.service.cli.thrift
 
TGetResultSetMetadataResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
TGetResultSetMetadataResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
TGetResultSetMetadataResp(TGetResultSetMetadataResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
Performs a deep copy on other.
TGetResultSetMetadataResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetSchemasReq - Class in org.apache.hive.service.cli.thrift
 
TGetSchemasReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
TGetSchemasReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
TGetSchemasReq(TGetSchemasReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasReq
Performs a deep copy on other.
TGetSchemasReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetSchemasResp - Class in org.apache.hive.service.cli.thrift
 
TGetSchemasResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
TGetSchemasResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
TGetSchemasResp(TGetSchemasResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetSchemasResp
Performs a deep copy on other.
TGetSchemasResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTablesReq - Class in org.apache.hive.service.cli.thrift
 
TGetTablesReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesReq
 
TGetTablesReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesReq
 
TGetTablesReq(TGetTablesReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesReq
Performs a deep copy on other.
TGetTablesReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTablesResp - Class in org.apache.hive.service.cli.thrift
 
TGetTablesResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesResp
 
TGetTablesResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesResp
 
TGetTablesResp(TGetTablesResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetTablesResp
Performs a deep copy on other.
TGetTablesResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTableTypesReq - Class in org.apache.hive.service.cli.thrift
 
TGetTableTypesReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
TGetTableTypesReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
TGetTableTypesReq(TGetTableTypesReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesReq
Performs a deep copy on other.
TGetTableTypesReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTableTypesResp - Class in org.apache.hive.service.cli.thrift
 
TGetTableTypesResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
TGetTableTypesResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
TGetTableTypesResp(TGetTableTypesResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetTableTypesResp
Performs a deep copy on other.
TGetTableTypesResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTypeInfoReq - Class in org.apache.hive.service.cli.thrift
 
TGetTypeInfoReq() - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
TGetTypeInfoReq(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
TGetTypeInfoReq(TGetTypeInfoReq) - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
Performs a deep copy on other.
TGetTypeInfoReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TGetTypeInfoResp - Class in org.apache.hive.service.cli.thrift
 
TGetTypeInfoResp() - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
TGetTypeInfoResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
TGetTypeInfoResp(TGetTypeInfoResp) - Constructor for class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
Performs a deep copy on other.
TGetTypeInfoResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THandleIdentifier - Class in org.apache.hive.service.cli.thrift
 
THandleIdentifier() - Constructor for class org.apache.hive.service.cli.thrift.THandleIdentifier
 
THandleIdentifier(ByteBuffer, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.THandleIdentifier
 
THandleIdentifier(THandleIdentifier) - Constructor for class org.apache.hive.service.cli.thrift.THandleIdentifier
Performs a deep copy on other.
THandleIdentifier._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THESHOLD_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
ThreadFactoryWithGarbageCleanup - Class in org.apache.hive.service.server
A ThreadFactory for constructing new HiveServer2 threads that lets you plug in custom cleanup code to be called before this thread is GC-ed.
ThreadFactoryWithGarbageCleanup(String) - Constructor for class org.apache.hive.service.server.ThreadFactoryWithGarbageCleanup
 
threadLocalVInt - Static variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
 
ThreadWithGarbageCleanup - Class in org.apache.hive.service.server
A HiveServer2 thread used to construct new server threads.
ThreadWithGarbageCleanup(Runnable) - Constructor for class org.apache.hive.service.server.ThreadWithGarbageCleanup
 
threshold - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
thrift_grammar - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
thrift_grammar(InputStream, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
thrift_grammar(InputStream) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Constructor with InputStream.
thrift_grammar(InputStream, String) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Constructor with InputStream and supplied encoding
thrift_grammar(Reader) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Constructor.
thrift_grammar(thrift_grammarTokenManager) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Constructor with generated Token Manager.
thrift_grammarConstants - Interface in org.apache.hadoop.hive.serde2.dynamic_type
Token literal values and constants.
thrift_grammarTokenManager - Class in org.apache.hadoop.hive.serde2.dynamic_type
Token Manager.
thrift_grammarTokenManager(SimpleCharStream) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Constructor.
thrift_grammarTokenManager(SimpleCharStream, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Constructor.
thrift_grammarTreeConstants - Interface in org.apache.hadoop.hive.serde2.dynamic_type
 
thrift_mode - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
ThriftBinaryCLIService - Class in org.apache.hive.service.cli.thrift
 
ThriftBinaryCLIService(CLIService) - Constructor for class org.apache.hive.service.cli.thrift.ThriftBinaryCLIService
 
ThriftByteStreamTypedSerDe - Class in org.apache.hadoop.hive.serde2.thrift
ThriftByteStreamTypedSerDe.
ThriftByteStreamTypedSerDe(Type, TProtocolFactory, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
ThriftCLIService - Class in org.apache.hive.service.cli.thrift
ThriftCLIService.
ThriftCLIService(CLIService, String) - Constructor for class org.apache.hive.service.cli.thrift.ThriftCLIService
 
ThriftCLIServiceClient - Class in org.apache.hive.service.cli.thrift
ThriftCLIServiceClient.
ThriftCLIServiceClient(TCLIService.Iface) - Constructor for class org.apache.hive.service.cli.thrift.ThriftCLIServiceClient
 
ThriftDeserializer - Class in org.apache.hadoop.hive.serde2.thrift
ThriftDeserializer.
ThriftDeserializer() - Constructor for class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
ThriftHive - Class in org.apache.hadoop.hive.service
 
ThriftHive() - Constructor for class org.apache.hadoop.hive.service.ThriftHive
 
ThriftHive.AsyncClient - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
ThriftHive.AsyncClient.clean_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.clean_call(AsyncMethodCallback<ThriftHive.AsyncClient.clean_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.clean_call
 
ThriftHive.AsyncClient.execute_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.execute_call(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
ThriftHive.AsyncClient.Factory - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.Factory
 
ThriftHive.AsyncClient.fetchAll_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchAll_call(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
ThriftHive.AsyncClient.fetchN_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchN_call(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
ThriftHive.AsyncClient.fetchOne_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchOne_call(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
ThriftHive.AsyncClient.getClusterStatus_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getClusterStatus_call(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
ThriftHive.AsyncClient.getQueryPlan_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getQueryPlan_call(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
ThriftHive.AsyncClient.getSchema_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getSchema_call(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
ThriftHive.AsyncClient.getThriftSchema_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getThriftSchema_call(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
ThriftHive.AsyncIface - Interface in org.apache.hadoop.hive.service
 
ThriftHive.clean_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.clean_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
ThriftHive.clean_args(ThriftHive.clean_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.clean_args
Performs a deep copy on other.
ThriftHive.clean_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.clean_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.clean_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
ThriftHive.clean_result(ThriftHive.clean_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.clean_result
Performs a deep copy on other.
ThriftHive.clean_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.Client - Class in org.apache.hadoop.hive.service
 
ThriftHive.Client(TProtocol) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client
 
ThriftHive.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client
 
ThriftHive.Client.Factory - Class in org.apache.hadoop.hive.service
 
ThriftHive.Client.Factory() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
ThriftHive.execute_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.execute_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
ThriftHive.execute_args(String) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
ThriftHive.execute_args(ThriftHive.execute_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
Performs a deep copy on other.
ThriftHive.execute_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.execute_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.execute_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
ThriftHive.execute_result(HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
ThriftHive.execute_result(ThriftHive.execute_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
Performs a deep copy on other.
ThriftHive.execute_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchAll_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchAll_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
ThriftHive.fetchAll_args(ThriftHive.fetchAll_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
Performs a deep copy on other.
ThriftHive.fetchAll_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchAll_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchAll_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
ThriftHive.fetchAll_result(List<String>, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
ThriftHive.fetchAll_result(ThriftHive.fetchAll_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Performs a deep copy on other.
ThriftHive.fetchAll_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchN_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchN_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
ThriftHive.fetchN_args(int) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
ThriftHive.fetchN_args(ThriftHive.fetchN_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Performs a deep copy on other.
ThriftHive.fetchN_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchN_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchN_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
ThriftHive.fetchN_result(List<String>, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
ThriftHive.fetchN_result(ThriftHive.fetchN_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Performs a deep copy on other.
ThriftHive.fetchN_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchOne_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchOne_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
ThriftHive.fetchOne_args(ThriftHive.fetchOne_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
Performs a deep copy on other.
ThriftHive.fetchOne_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchOne_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchOne_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
ThriftHive.fetchOne_result(String, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
ThriftHive.fetchOne_result(ThriftHive.fetchOne_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Performs a deep copy on other.
ThriftHive.fetchOne_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getClusterStatus_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getClusterStatus_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
ThriftHive.getClusterStatus_args(ThriftHive.getClusterStatus_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
Performs a deep copy on other.
ThriftHive.getClusterStatus_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getClusterStatus_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getClusterStatus_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
ThriftHive.getClusterStatus_result(HiveClusterStatus, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
ThriftHive.getClusterStatus_result(ThriftHive.getClusterStatus_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Performs a deep copy on other.
ThriftHive.getClusterStatus_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getQueryPlan_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getQueryPlan_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
ThriftHive.getQueryPlan_args(ThriftHive.getQueryPlan_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
Performs a deep copy on other.
ThriftHive.getQueryPlan_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getQueryPlan_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getQueryPlan_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
ThriftHive.getQueryPlan_result(QueryPlan, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
ThriftHive.getQueryPlan_result(ThriftHive.getQueryPlan_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Performs a deep copy on other.
ThriftHive.getQueryPlan_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getSchema_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getSchema_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
ThriftHive.getSchema_args(ThriftHive.getSchema_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
Performs a deep copy on other.
ThriftHive.getSchema_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getSchema_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getSchema_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
ThriftHive.getSchema_result(Schema, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
ThriftHive.getSchema_result(ThriftHive.getSchema_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Performs a deep copy on other.
ThriftHive.getSchema_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getThriftSchema_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getThriftSchema_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
ThriftHive.getThriftSchema_args(ThriftHive.getThriftSchema_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
Performs a deep copy on other.
ThriftHive.getThriftSchema_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getThriftSchema_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getThriftSchema_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
ThriftHive.getThriftSchema_result(Schema, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
ThriftHive.getThriftSchema_result(ThriftHive.getThriftSchema_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Performs a deep copy on other.
ThriftHive.getThriftSchema_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.Iface - Interface in org.apache.hadoop.hive.service
 
ThriftHive.Processor<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor(I) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor
 
ThriftHive.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor
 
ThriftHive.Processor.clean<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.clean() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.clean
 
ThriftHive.Processor.execute<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.execute() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.execute
 
ThriftHive.Processor.fetchAll<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.fetchAll() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchAll
 
ThriftHive.Processor.fetchN<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.fetchN() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchN
 
ThriftHive.Processor.fetchOne<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.fetchOne() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.fetchOne
 
ThriftHive.Processor.getClusterStatus<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.getClusterStatus() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.getClusterStatus
 
ThriftHive.Processor.getQueryPlan<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.getQueryPlan() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.getQueryPlan
 
ThriftHive.Processor.getSchema<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.getSchema() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.getSchema
 
ThriftHive.Processor.getThriftSchema<I extends ThriftHive.Iface> - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor.getThriftSchema() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor.getThriftSchema
 
ThriftHiveMetastore - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore
 
ThriftHiveMetastore.abort_txn_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.abort_txn_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
ThriftHiveMetastore.abort_txn_args(AbortTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
ThriftHiveMetastore.abort_txn_args(ThriftHiveMetastore.abort_txn_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
Performs a deep copy on other.
ThriftHiveMetastore.abort_txn_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.abort_txn_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.abort_txn_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
ThriftHiveMetastore.abort_txn_result(NoSuchTxnException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
ThriftHiveMetastore.abort_txn_result(ThriftHiveMetastore.abort_txn_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
Performs a deep copy on other.
ThriftHiveMetastore.abort_txn_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_dynamic_partitions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_dynamic_partitions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
ThriftHiveMetastore.add_dynamic_partitions_args(AddDynamicPartitions) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
ThriftHiveMetastore.add_dynamic_partitions_args(ThriftHiveMetastore.add_dynamic_partitions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
Performs a deep copy on other.
ThriftHiveMetastore.add_dynamic_partitions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_dynamic_partitions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_dynamic_partitions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
ThriftHiveMetastore.add_dynamic_partitions_result(NoSuchTxnException, TxnAbortedException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
ThriftHiveMetastore.add_dynamic_partitions_result(ThriftHiveMetastore.add_dynamic_partitions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
Performs a deep copy on other.
ThriftHiveMetastore.add_dynamic_partitions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_index_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_index_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
ThriftHiveMetastore.add_index_args(Index, Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
ThriftHiveMetastore.add_index_args(ThriftHiveMetastore.add_index_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Performs a deep copy on other.
ThriftHiveMetastore.add_index_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_index_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_index_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
ThriftHiveMetastore.add_index_result(Index, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
ThriftHiveMetastore.add_index_result(ThriftHiveMetastore.add_index_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Performs a deep copy on other.
ThriftHiveMetastore.add_index_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
ThriftHiveMetastore.add_partition_args(Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
ThriftHiveMetastore.add_partition_args(ThriftHiveMetastore.add_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
ThriftHiveMetastore.add_partition_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
ThriftHiveMetastore.add_partition_result(ThriftHiveMetastore.add_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
ThriftHiveMetastore.add_partition_with_environment_context_args(Partition, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
ThriftHiveMetastore.add_partition_with_environment_context_args(ThriftHiveMetastore.add_partition_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
ThriftHiveMetastore.add_partition_with_environment_context_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
ThriftHiveMetastore.add_partition_with_environment_context_result(ThriftHiveMetastore.add_partition_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
ThriftHiveMetastore.add_partitions_args(List<Partition>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
ThriftHiveMetastore.add_partitions_args(ThriftHiveMetastore.add_partitions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_pspec_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_pspec_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
ThriftHiveMetastore.add_partitions_pspec_args(List<PartitionSpec>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
ThriftHiveMetastore.add_partitions_pspec_args(ThriftHiveMetastore.add_partitions_pspec_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_pspec_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_pspec_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_pspec_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
ThriftHiveMetastore.add_partitions_pspec_result(int, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
ThriftHiveMetastore.add_partitions_pspec_result(ThriftHiveMetastore.add_partitions_pspec_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_pspec_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_req_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_req_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
ThriftHiveMetastore.add_partitions_req_args(AddPartitionsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
ThriftHiveMetastore.add_partitions_req_args(ThriftHiveMetastore.add_partitions_req_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_req_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_req_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_req_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
ThriftHiveMetastore.add_partitions_req_result(AddPartitionsResult, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
ThriftHiveMetastore.add_partitions_req_result(ThriftHiveMetastore.add_partitions_req_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_req_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partitions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partitions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
ThriftHiveMetastore.add_partitions_result(int, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
ThriftHiveMetastore.add_partitions_result(ThriftHiveMetastore.add_partitions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partitions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
ThriftHiveMetastore.alter_database_args(String, Database) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
ThriftHiveMetastore.alter_database_args(ThriftHiveMetastore.alter_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
ThriftHiveMetastore.alter_database_result(MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
ThriftHiveMetastore.alter_database_result(ThriftHiveMetastore.alter_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_function_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_function_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
ThriftHiveMetastore.alter_function_args(String, String, Function) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
ThriftHiveMetastore.alter_function_args(ThriftHiveMetastore.alter_function_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_function_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_function_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_function_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
ThriftHiveMetastore.alter_function_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
ThriftHiveMetastore.alter_function_result(ThriftHiveMetastore.alter_function_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_function_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_index_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_index_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
ThriftHiveMetastore.alter_index_args(String, String, String, Index) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
ThriftHiveMetastore.alter_index_args(ThriftHiveMetastore.alter_index_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_index_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_index_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_index_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
ThriftHiveMetastore.alter_index_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
ThriftHiveMetastore.alter_index_result(ThriftHiveMetastore.alter_index_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_index_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
ThriftHiveMetastore.alter_partition_args(String, String, Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
ThriftHiveMetastore.alter_partition_args(ThriftHiveMetastore.alter_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
ThriftHiveMetastore.alter_partition_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
ThriftHiveMetastore.alter_partition_result(ThriftHiveMetastore.alter_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
ThriftHiveMetastore.alter_partition_with_environment_context_args(String, String, Partition, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
ThriftHiveMetastore.alter_partition_with_environment_context_args(ThriftHiveMetastore.alter_partition_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
ThriftHiveMetastore.alter_partition_with_environment_context_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
ThriftHiveMetastore.alter_partition_with_environment_context_result(ThriftHiveMetastore.alter_partition_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partitions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partitions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
ThriftHiveMetastore.alter_partitions_args(String, String, List<Partition>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
ThriftHiveMetastore.alter_partitions_args(ThriftHiveMetastore.alter_partitions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_partitions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partitions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partitions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
ThriftHiveMetastore.alter_partitions_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
ThriftHiveMetastore.alter_partitions_result(ThriftHiveMetastore.alter_partitions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_partitions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
ThriftHiveMetastore.alter_table_args(String, String, Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
ThriftHiveMetastore.alter_table_args(ThriftHiveMetastore.alter_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
ThriftHiveMetastore.alter_table_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
ThriftHiveMetastore.alter_table_result(ThriftHiveMetastore.alter_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_with_cascade_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_with_cascade_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
ThriftHiveMetastore.alter_table_with_cascade_args(String, String, Table, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
ThriftHiveMetastore.alter_table_with_cascade_args(ThriftHiveMetastore.alter_table_with_cascade_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_with_cascade_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_with_cascade_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_with_cascade_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
ThriftHiveMetastore.alter_table_with_cascade_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
ThriftHiveMetastore.alter_table_with_cascade_result(ThriftHiveMetastore.alter_table_with_cascade_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_with_cascade_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
ThriftHiveMetastore.alter_table_with_environment_context_args(String, String, Table, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
ThriftHiveMetastore.alter_table_with_environment_context_args(ThriftHiveMetastore.alter_table_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
ThriftHiveMetastore.alter_table_with_environment_context_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
ThriftHiveMetastore.alter_table_with_environment_context_result(ThriftHiveMetastore.alter_table_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
ThriftHiveMetastore.append_partition_args(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
ThriftHiveMetastore.append_partition_args(ThriftHiveMetastore.append_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
ThriftHiveMetastore.append_partition_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
ThriftHiveMetastore.append_partition_by_name_args(ThriftHiveMetastore.append_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
ThriftHiveMetastore.append_partition_by_name_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
ThriftHiveMetastore.append_partition_by_name_result(ThriftHiveMetastore.append_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args(String, String, String, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args(ThriftHiveMetastore.append_partition_by_name_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result(ThriftHiveMetastore.append_partition_by_name_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
ThriftHiveMetastore.append_partition_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
ThriftHiveMetastore.append_partition_result(ThriftHiveMetastore.append_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
ThriftHiveMetastore.append_partition_with_environment_context_args(String, String, List<String>, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
ThriftHiveMetastore.append_partition_with_environment_context_args(ThriftHiveMetastore.append_partition_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
ThriftHiveMetastore.append_partition_with_environment_context_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
ThriftHiveMetastore.append_partition_with_environment_context_result(ThriftHiveMetastore.append_partition_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.AsyncClient - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
ThriftHiveMetastore.AsyncClient.abort_txn_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.abort_txn_call(AbortTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.abort_txn_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.abort_txn_call
 
ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call(AddDynamicPartitions, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call
 
ThriftHiveMetastore.AsyncClient.add_index_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_index_call(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
ThriftHiveMetastore.AsyncClient.add_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partition_call(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call(Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.add_partitions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partitions_call(List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_call
 
ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call(List<PartitionSpec>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call
 
ThriftHiveMetastore.AsyncClient.add_partitions_req_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partitions_req_call(AddPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partitions_req_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_req_call
 
ThriftHiveMetastore.AsyncClient.alter_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_database_call(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
ThriftHiveMetastore.AsyncClient.alter_function_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_function_call(String, String, Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_function_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_function_call
 
ThriftHiveMetastore.AsyncClient.alter_index_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_index_call(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
ThriftHiveMetastore.AsyncClient.alter_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_partition_call(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call(String, String, Partition, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.alter_partitions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_partitions_call(String, String, List<Partition>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partitions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partitions_call
 
ThriftHiveMetastore.AsyncClient.alter_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_table_call(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call(String, String, Table, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call
 
ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call(String, String, Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call(String, String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.append_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_call(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call(String, String, List<String>, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.check_lock_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.check_lock_call(CheckLockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.check_lock_call
 
ThriftHiveMetastore.AsyncClient.commit_txn_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.commit_txn_call(CommitTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.commit_txn_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.commit_txn_call
 
ThriftHiveMetastore.AsyncClient.compact_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.compact_call(CompactionRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.compact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.compact_call
 
ThriftHiveMetastore.AsyncClient.create_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_database_call(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
ThriftHiveMetastore.AsyncClient.create_function_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_function_call(Function, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_function_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_function_call
 
ThriftHiveMetastore.AsyncClient.create_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_role_call(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
ThriftHiveMetastore.AsyncClient.create_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_table_call(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call(Table, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.create_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_type_call(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call
 
ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call
 
ThriftHiveMetastore.AsyncClient.drop_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_database_call(String, boolean, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
ThriftHiveMetastore.AsyncClient.drop_function_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_function_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_function_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_function_call
 
ThriftHiveMetastore.AsyncClient.drop_index_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_index_by_name_call(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call(String, String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_call(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call(String, String, List<String>, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.drop_partitions_req_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partitions_req_call(DropPartitionsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partitions_req_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partitions_req_call
 
ThriftHiveMetastore.AsyncClient.drop_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_role_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
ThriftHiveMetastore.AsyncClient.drop_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_table_call(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call(String, String, boolean, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.drop_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_type_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
ThriftHiveMetastore.AsyncClient.exchange_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.exchange_partition_call(Map<String, String>, String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.exchange_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.exchange_partition_call
 
ThriftHiveMetastore.AsyncClient.Factory - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.Factory
 
ThriftHiveMetastore.AsyncClient.fire_listener_event_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.fire_listener_event_call(FireEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.fire_listener_event_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.fire_listener_event_call
 
ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call
 
ThriftHiveMetastore.AsyncClient.get_all_databases_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_all_databases_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
ThriftHiveMetastore.AsyncClient.get_all_tables_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_all_tables_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
ThriftHiveMetastore.AsyncClient.get_config_value_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_config_value_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call
 
ThriftHiveMetastore.AsyncClient.get_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_database_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
ThriftHiveMetastore.AsyncClient.get_databases_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_databases_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.get_fields_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_fields_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.get_function_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_function_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_function_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_function_call
 
ThriftHiveMetastore.AsyncClient.get_functions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_functions_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_functions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_functions_call
 
ThriftHiveMetastore.AsyncClient.get_index_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_index_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
ThriftHiveMetastore.AsyncClient.get_index_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_index_names_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
ThriftHiveMetastore.AsyncClient.get_indexes_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_indexes_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
ThriftHiveMetastore.AsyncClient.get_next_notification_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_next_notification_call(NotificationEventRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_next_notification_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_next_notification_call
 
ThriftHiveMetastore.AsyncClient.get_open_txns_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_open_txns_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_call
 
ThriftHiveMetastore.AsyncClient.get_open_txns_info_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_open_txns_info_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_open_txns_info_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_info_call
 
ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call(String, String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call
 
ThriftHiveMetastore.AsyncClient.get_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.get_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_call(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call(String, String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call
 
ThriftHiveMetastore.AsyncClient.get_partition_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_names_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call(PartitionsByExprRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_call(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call(String, String, int, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call(PartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_principals_in_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_principals_in_role_call(GetPrincipalsInRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_principals_in_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_principals_in_role_call
 
ThriftHiveMetastore.AsyncClient.get_privilege_set_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_privilege_set_call(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call(GetRoleGrantsForPrincipalRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call
 
ThriftHiveMetastore.AsyncClient.get_role_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_role_names_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
ThriftHiveMetastore.AsyncClient.get_schema_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_schema_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call(String, String, EnvironmentContext, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call
 
ThriftHiveMetastore.AsyncClient.get_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call
 
ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call
 
ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call
 
ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call(TableStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call
 
ThriftHiveMetastore.AsyncClient.get_tables_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_tables_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
ThriftHiveMetastore.AsyncClient.get_type_all_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_type_all_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
ThriftHiveMetastore.AsyncClient.get_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_type_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
ThriftHiveMetastore.AsyncClient.getMetaConf_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.getMetaConf_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.getMetaConf_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.getMetaConf_call
 
ThriftHiveMetastore.AsyncClient.grant_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_privileges_call(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call(GrantRevokePrivilegeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call
 
ThriftHiveMetastore.AsyncClient.grant_revoke_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_revoke_role_call(GrantRevokeRoleRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_revoke_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_role_call
 
ThriftHiveMetastore.AsyncClient.grant_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_role_call(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
ThriftHiveMetastore.AsyncClient.heartbeat_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.heartbeat_call(HeartbeatRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_call
 
ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call(HeartbeatTxnRangeRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call
 
ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call
 
ThriftHiveMetastore.AsyncClient.list_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.list_privileges_call(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
ThriftHiveMetastore.AsyncClient.list_roles_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.list_roles_call(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
ThriftHiveMetastore.AsyncClient.lock_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.lock_call(LockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.lock_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.lock_call
 
ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call(String, String, Map<String, String>, PartitionEventType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call
 
ThriftHiveMetastore.AsyncClient.open_txns_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.open_txns_call(OpenTxnRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.open_txns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.open_txns_call
 
ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call(List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call
 
ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
ThriftHiveMetastore.AsyncClient.rename_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.rename_partition_call(String, String, List<String>, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.rename_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.rename_partition_call
 
ThriftHiveMetastore.AsyncClient.renew_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.renew_delegation_token_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.revoke_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.revoke_privileges_call(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
ThriftHiveMetastore.AsyncClient.revoke_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.revoke_role_call(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call(SetPartitionsStatsRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call
 
ThriftHiveMetastore.AsyncClient.set_ugi_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.set_ugi_call(String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.set_ugi_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_ugi_call
 
ThriftHiveMetastore.AsyncClient.setMetaConf_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.setMetaConf_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.setMetaConf_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.setMetaConf_call
 
ThriftHiveMetastore.AsyncClient.show_compact_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.show_compact_call(ShowCompactRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_compact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_compact_call
 
ThriftHiveMetastore.AsyncClient.show_locks_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.show_locks_call(ShowLocksRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.show_locks_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_locks_call
 
ThriftHiveMetastore.AsyncClient.unlock_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.unlock_call(UnlockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.unlock_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.unlock_call
 
ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call
 
ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call
 
ThriftHiveMetastore.AsyncIface - Interface in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
ThriftHiveMetastore.cancel_delegation_token_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
ThriftHiveMetastore.cancel_delegation_token_args(ThriftHiveMetastore.cancel_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.cancel_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.cancel_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
ThriftHiveMetastore.cancel_delegation_token_result(MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
ThriftHiveMetastore.cancel_delegation_token_result(ThriftHiveMetastore.cancel_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.cancel_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.check_lock_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.check_lock_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
ThriftHiveMetastore.check_lock_args(CheckLockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
ThriftHiveMetastore.check_lock_args(ThriftHiveMetastore.check_lock_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
Performs a deep copy on other.
ThriftHiveMetastore.check_lock_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.check_lock_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.check_lock_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
ThriftHiveMetastore.check_lock_result(LockResponse, NoSuchTxnException, TxnAbortedException, NoSuchLockException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
ThriftHiveMetastore.check_lock_result(ThriftHiveMetastore.check_lock_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
Performs a deep copy on other.
ThriftHiveMetastore.check_lock_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Client - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Client(TProtocol) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
ThriftHiveMetastore.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
ThriftHiveMetastore.Client.Factory - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Client.Factory() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
ThriftHiveMetastore.commit_txn_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.commit_txn_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
ThriftHiveMetastore.commit_txn_args(CommitTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
ThriftHiveMetastore.commit_txn_args(ThriftHiveMetastore.commit_txn_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
Performs a deep copy on other.
ThriftHiveMetastore.commit_txn_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.commit_txn_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.commit_txn_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
ThriftHiveMetastore.commit_txn_result(NoSuchTxnException, TxnAbortedException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
ThriftHiveMetastore.commit_txn_result(ThriftHiveMetastore.commit_txn_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
Performs a deep copy on other.
ThriftHiveMetastore.commit_txn_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.compact_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.compact_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
ThriftHiveMetastore.compact_args(CompactionRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
ThriftHiveMetastore.compact_args(ThriftHiveMetastore.compact_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
Performs a deep copy on other.
ThriftHiveMetastore.compact_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.compact_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.compact_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
ThriftHiveMetastore.compact_result(ThriftHiveMetastore.compact_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
Performs a deep copy on other.
ThriftHiveMetastore.compact_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
ThriftHiveMetastore.create_database_args(Database) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
ThriftHiveMetastore.create_database_args(ThriftHiveMetastore.create_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Performs a deep copy on other.
ThriftHiveMetastore.create_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
ThriftHiveMetastore.create_database_result(AlreadyExistsException, InvalidObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
ThriftHiveMetastore.create_database_result(ThriftHiveMetastore.create_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Performs a deep copy on other.
ThriftHiveMetastore.create_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_function_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_function_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
ThriftHiveMetastore.create_function_args(Function) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
ThriftHiveMetastore.create_function_args(ThriftHiveMetastore.create_function_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
Performs a deep copy on other.
ThriftHiveMetastore.create_function_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_function_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_function_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
ThriftHiveMetastore.create_function_result(AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
ThriftHiveMetastore.create_function_result(ThriftHiveMetastore.create_function_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
Performs a deep copy on other.
ThriftHiveMetastore.create_function_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
ThriftHiveMetastore.create_role_args(Role) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
ThriftHiveMetastore.create_role_args(ThriftHiveMetastore.create_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Performs a deep copy on other.
ThriftHiveMetastore.create_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
ThriftHiveMetastore.create_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
ThriftHiveMetastore.create_role_result(ThriftHiveMetastore.create_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Performs a deep copy on other.
ThriftHiveMetastore.create_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
ThriftHiveMetastore.create_table_args(Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
ThriftHiveMetastore.create_table_args(ThriftHiveMetastore.create_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Performs a deep copy on other.
ThriftHiveMetastore.create_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
ThriftHiveMetastore.create_table_result(AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
ThriftHiveMetastore.create_table_result(ThriftHiveMetastore.create_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Performs a deep copy on other.
ThriftHiveMetastore.create_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
ThriftHiveMetastore.create_table_with_environment_context_args(Table, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
ThriftHiveMetastore.create_table_with_environment_context_args(ThriftHiveMetastore.create_table_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.create_table_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
ThriftHiveMetastore.create_table_with_environment_context_result(AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
ThriftHiveMetastore.create_table_with_environment_context_result(ThriftHiveMetastore.create_table_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.create_table_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
ThriftHiveMetastore.create_type_args(Type) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
ThriftHiveMetastore.create_type_args(ThriftHiveMetastore.create_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Performs a deep copy on other.
ThriftHiveMetastore.create_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
ThriftHiveMetastore.create_type_result(boolean, AlreadyExistsException, InvalidObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
ThriftHiveMetastore.create_type_result(ThriftHiveMetastore.create_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Performs a deep copy on other.
ThriftHiveMetastore.create_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.delete_partition_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.delete_partition_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
ThriftHiveMetastore.delete_partition_column_statistics_args(String, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
ThriftHiveMetastore.delete_partition_column_statistics_args(ThriftHiveMetastore.delete_partition_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.delete_partition_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.delete_partition_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.delete_partition_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
ThriftHiveMetastore.delete_partition_column_statistics_result(boolean, NoSuchObjectException, MetaException, InvalidObjectException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
ThriftHiveMetastore.delete_partition_column_statistics_result(ThriftHiveMetastore.delete_partition_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.delete_partition_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.delete_table_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.delete_table_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
ThriftHiveMetastore.delete_table_column_statistics_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
ThriftHiveMetastore.delete_table_column_statistics_args(ThriftHiveMetastore.delete_table_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.delete_table_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.delete_table_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.delete_table_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
ThriftHiveMetastore.delete_table_column_statistics_result(boolean, NoSuchObjectException, MetaException, InvalidObjectException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
ThriftHiveMetastore.delete_table_column_statistics_result(ThriftHiveMetastore.delete_table_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.delete_table_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
ThriftHiveMetastore.drop_database_args(String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
ThriftHiveMetastore.drop_database_args(ThriftHiveMetastore.drop_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
ThriftHiveMetastore.drop_database_result(NoSuchObjectException, InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
ThriftHiveMetastore.drop_database_result(ThriftHiveMetastore.drop_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_function_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_function_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
ThriftHiveMetastore.drop_function_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
ThriftHiveMetastore.drop_function_args(ThriftHiveMetastore.drop_function_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_function_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_function_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_function_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
ThriftHiveMetastore.drop_function_result(NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
ThriftHiveMetastore.drop_function_result(ThriftHiveMetastore.drop_function_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_function_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_index_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_index_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
ThriftHiveMetastore.drop_index_by_name_args(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
ThriftHiveMetastore.drop_index_by_name_args(ThriftHiveMetastore.drop_index_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_index_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_index_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_index_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
ThriftHiveMetastore.drop_index_by_name_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
ThriftHiveMetastore.drop_index_by_name_result(ThriftHiveMetastore.drop_index_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_index_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
ThriftHiveMetastore.drop_partition_args(String, String, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
ThriftHiveMetastore.drop_partition_args(ThriftHiveMetastore.drop_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
ThriftHiveMetastore.drop_partition_by_name_args(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
ThriftHiveMetastore.drop_partition_by_name_args(ThriftHiveMetastore.drop_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
ThriftHiveMetastore.drop_partition_by_name_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
ThriftHiveMetastore.drop_partition_by_name_result(ThriftHiveMetastore.drop_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args(String, String, String, boolean, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result(ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
ThriftHiveMetastore.drop_partition_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
ThriftHiveMetastore.drop_partition_result(ThriftHiveMetastore.drop_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
ThriftHiveMetastore.drop_partition_with_environment_context_args(String, String, List<String>, boolean, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
ThriftHiveMetastore.drop_partition_with_environment_context_args(ThriftHiveMetastore.drop_partition_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
ThriftHiveMetastore.drop_partition_with_environment_context_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
ThriftHiveMetastore.drop_partition_with_environment_context_result(ThriftHiveMetastore.drop_partition_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partitions_req_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partitions_req_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
ThriftHiveMetastore.drop_partitions_req_args(DropPartitionsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
ThriftHiveMetastore.drop_partitions_req_args(ThriftHiveMetastore.drop_partitions_req_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partitions_req_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partitions_req_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partitions_req_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
ThriftHiveMetastore.drop_partitions_req_result(DropPartitionsResult, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
ThriftHiveMetastore.drop_partitions_req_result(ThriftHiveMetastore.drop_partitions_req_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partitions_req_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
ThriftHiveMetastore.drop_role_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
ThriftHiveMetastore.drop_role_args(ThriftHiveMetastore.drop_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
ThriftHiveMetastore.drop_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
ThriftHiveMetastore.drop_role_result(ThriftHiveMetastore.drop_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
ThriftHiveMetastore.drop_table_args(String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
ThriftHiveMetastore.drop_table_args(ThriftHiveMetastore.drop_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
ThriftHiveMetastore.drop_table_result(NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
ThriftHiveMetastore.drop_table_result(ThriftHiveMetastore.drop_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
ThriftHiveMetastore.drop_table_with_environment_context_args(String, String, boolean, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
ThriftHiveMetastore.drop_table_with_environment_context_args(ThriftHiveMetastore.drop_table_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
ThriftHiveMetastore.drop_table_with_environment_context_result(NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
ThriftHiveMetastore.drop_table_with_environment_context_result(ThriftHiveMetastore.drop_table_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
ThriftHiveMetastore.drop_type_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
ThriftHiveMetastore.drop_type_args(ThriftHiveMetastore.drop_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
ThriftHiveMetastore.drop_type_result(boolean, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
ThriftHiveMetastore.drop_type_result(ThriftHiveMetastore.drop_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.exchange_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.exchange_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
ThriftHiveMetastore.exchange_partition_args(Map<String, String>, String, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
ThriftHiveMetastore.exchange_partition_args(ThriftHiveMetastore.exchange_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.exchange_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.exchange_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.exchange_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
ThriftHiveMetastore.exchange_partition_result(Partition, MetaException, NoSuchObjectException, InvalidObjectException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
ThriftHiveMetastore.exchange_partition_result(ThriftHiveMetastore.exchange_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.exchange_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.fire_listener_event_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.fire_listener_event_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
ThriftHiveMetastore.fire_listener_event_args(FireEventRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
ThriftHiveMetastore.fire_listener_event_args(ThriftHiveMetastore.fire_listener_event_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
Performs a deep copy on other.
ThriftHiveMetastore.fire_listener_event_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.fire_listener_event_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.fire_listener_event_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
ThriftHiveMetastore.fire_listener_event_result(FireEventResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
ThriftHiveMetastore.fire_listener_event_result(ThriftHiveMetastore.fire_listener_event_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
Performs a deep copy on other.
ThriftHiveMetastore.fire_listener_event_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_aggr_stats_for_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_aggr_stats_for_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
ThriftHiveMetastore.get_aggr_stats_for_args(PartitionsStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
ThriftHiveMetastore.get_aggr_stats_for_args(ThriftHiveMetastore.get_aggr_stats_for_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
Performs a deep copy on other.
ThriftHiveMetastore.get_aggr_stats_for_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_aggr_stats_for_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_aggr_stats_for_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
ThriftHiveMetastore.get_aggr_stats_for_result(AggrStats, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
ThriftHiveMetastore.get_aggr_stats_for_result(ThriftHiveMetastore.get_aggr_stats_for_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
Performs a deep copy on other.
ThriftHiveMetastore.get_aggr_stats_for_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_databases_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_databases_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
ThriftHiveMetastore.get_all_databases_args(ThriftHiveMetastore.get_all_databases_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
Performs a deep copy on other.
ThriftHiveMetastore.get_all_databases_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_databases_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_databases_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
ThriftHiveMetastore.get_all_databases_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
ThriftHiveMetastore.get_all_databases_result(ThriftHiveMetastore.get_all_databases_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Performs a deep copy on other.
ThriftHiveMetastore.get_all_databases_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_tables_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_tables_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
ThriftHiveMetastore.get_all_tables_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
ThriftHiveMetastore.get_all_tables_args(ThriftHiveMetastore.get_all_tables_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Performs a deep copy on other.
ThriftHiveMetastore.get_all_tables_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_tables_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_tables_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
ThriftHiveMetastore.get_all_tables_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
ThriftHiveMetastore.get_all_tables_result(ThriftHiveMetastore.get_all_tables_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Performs a deep copy on other.
ThriftHiveMetastore.get_all_tables_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_config_value_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_config_value_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
ThriftHiveMetastore.get_config_value_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
ThriftHiveMetastore.get_config_value_args(ThriftHiveMetastore.get_config_value_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Performs a deep copy on other.
ThriftHiveMetastore.get_config_value_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_config_value_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_config_value_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
ThriftHiveMetastore.get_config_value_result(String, ConfigValSecurityException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
ThriftHiveMetastore.get_config_value_result(ThriftHiveMetastore.get_config_value_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Performs a deep copy on other.
ThriftHiveMetastore.get_config_value_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_current_notificationEventId_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_current_notificationEventId_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
ThriftHiveMetastore.get_current_notificationEventId_args(ThriftHiveMetastore.get_current_notificationEventId_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
Performs a deep copy on other.
ThriftHiveMetastore.get_current_notificationEventId_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_current_notificationEventId_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_current_notificationEventId_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
ThriftHiveMetastore.get_current_notificationEventId_result(CurrentNotificationEventId) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
ThriftHiveMetastore.get_current_notificationEventId_result(ThriftHiveMetastore.get_current_notificationEventId_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
Performs a deep copy on other.
ThriftHiveMetastore.get_current_notificationEventId_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
ThriftHiveMetastore.get_database_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
ThriftHiveMetastore.get_database_args(ThriftHiveMetastore.get_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Performs a deep copy on other.
ThriftHiveMetastore.get_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
ThriftHiveMetastore.get_database_result(Database, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
ThriftHiveMetastore.get_database_result(ThriftHiveMetastore.get_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Performs a deep copy on other.
ThriftHiveMetastore.get_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_databases_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_databases_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
ThriftHiveMetastore.get_databases_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
ThriftHiveMetastore.get_databases_args(ThriftHiveMetastore.get_databases_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Performs a deep copy on other.
ThriftHiveMetastore.get_databases_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_databases_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_databases_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
ThriftHiveMetastore.get_databases_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
ThriftHiveMetastore.get_databases_result(ThriftHiveMetastore.get_databases_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Performs a deep copy on other.
ThriftHiveMetastore.get_databases_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
ThriftHiveMetastore.get_delegation_token_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
ThriftHiveMetastore.get_delegation_token_args(ThriftHiveMetastore.get_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
ThriftHiveMetastore.get_delegation_token_result(String, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
ThriftHiveMetastore.get_delegation_token_result(ThriftHiveMetastore.get_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
ThriftHiveMetastore.get_fields_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
ThriftHiveMetastore.get_fields_args(ThriftHiveMetastore.get_fields_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
ThriftHiveMetastore.get_fields_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
ThriftHiveMetastore.get_fields_result(ThriftHiveMetastore.get_fields_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
ThriftHiveMetastore.get_fields_with_environment_context_args(String, String, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
ThriftHiveMetastore.get_fields_with_environment_context_args(ThriftHiveMetastore.get_fields_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
ThriftHiveMetastore.get_fields_with_environment_context_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
ThriftHiveMetastore.get_fields_with_environment_context_result(ThriftHiveMetastore.get_fields_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_function_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_function_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
ThriftHiveMetastore.get_function_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
ThriftHiveMetastore.get_function_args(ThriftHiveMetastore.get_function_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
Performs a deep copy on other.
ThriftHiveMetastore.get_function_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_function_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_function_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
ThriftHiveMetastore.get_function_result(Function, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
ThriftHiveMetastore.get_function_result(ThriftHiveMetastore.get_function_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
Performs a deep copy on other.
ThriftHiveMetastore.get_function_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_functions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_functions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
ThriftHiveMetastore.get_functions_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
ThriftHiveMetastore.get_functions_args(ThriftHiveMetastore.get_functions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
Performs a deep copy on other.
ThriftHiveMetastore.get_functions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_functions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_functions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
ThriftHiveMetastore.get_functions_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
ThriftHiveMetastore.get_functions_result(ThriftHiveMetastore.get_functions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
Performs a deep copy on other.
ThriftHiveMetastore.get_functions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
ThriftHiveMetastore.get_index_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
ThriftHiveMetastore.get_index_by_name_args(ThriftHiveMetastore.get_index_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.get_index_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
ThriftHiveMetastore.get_index_by_name_result(Index, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
ThriftHiveMetastore.get_index_by_name_result(ThriftHiveMetastore.get_index_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.get_index_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
ThriftHiveMetastore.get_index_names_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
ThriftHiveMetastore.get_index_names_args(ThriftHiveMetastore.get_index_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_index_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
ThriftHiveMetastore.get_index_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
ThriftHiveMetastore.get_index_names_result(ThriftHiveMetastore.get_index_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_index_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_indexes_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_indexes_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
ThriftHiveMetastore.get_indexes_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
ThriftHiveMetastore.get_indexes_args(ThriftHiveMetastore.get_indexes_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Performs a deep copy on other.
ThriftHiveMetastore.get_indexes_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_indexes_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_indexes_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
ThriftHiveMetastore.get_indexes_result(List<Index>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
ThriftHiveMetastore.get_indexes_result(ThriftHiveMetastore.get_indexes_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Performs a deep copy on other.
ThriftHiveMetastore.get_indexes_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_next_notification_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_next_notification_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
ThriftHiveMetastore.get_next_notification_args(NotificationEventRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
ThriftHiveMetastore.get_next_notification_args(ThriftHiveMetastore.get_next_notification_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
Performs a deep copy on other.
ThriftHiveMetastore.get_next_notification_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_next_notification_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_next_notification_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
ThriftHiveMetastore.get_next_notification_result(NotificationEventResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
ThriftHiveMetastore.get_next_notification_result(ThriftHiveMetastore.get_next_notification_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
Performs a deep copy on other.
ThriftHiveMetastore.get_next_notification_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_open_txns_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_open_txns_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
ThriftHiveMetastore.get_open_txns_args(ThriftHiveMetastore.get_open_txns_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
Performs a deep copy on other.
ThriftHiveMetastore.get_open_txns_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_open_txns_info_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_open_txns_info_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
ThriftHiveMetastore.get_open_txns_info_args(ThriftHiveMetastore.get_open_txns_info_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
Performs a deep copy on other.
ThriftHiveMetastore.get_open_txns_info_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_open_txns_info_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_open_txns_info_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
ThriftHiveMetastore.get_open_txns_info_result(GetOpenTxnsInfoResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
ThriftHiveMetastore.get_open_txns_info_result(ThriftHiveMetastore.get_open_txns_info_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
Performs a deep copy on other.
ThriftHiveMetastore.get_open_txns_info_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_open_txns_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_open_txns_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
ThriftHiveMetastore.get_open_txns_result(GetOpenTxnsResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
ThriftHiveMetastore.get_open_txns_result(ThriftHiveMetastore.get_open_txns_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
Performs a deep copy on other.
ThriftHiveMetastore.get_open_txns_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_part_specs_by_filter_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_part_specs_by_filter_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
ThriftHiveMetastore.get_part_specs_by_filter_args(String, String, String, int) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
ThriftHiveMetastore.get_part_specs_by_filter_args(ThriftHiveMetastore.get_part_specs_by_filter_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
Performs a deep copy on other.
ThriftHiveMetastore.get_part_specs_by_filter_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_part_specs_by_filter_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_part_specs_by_filter_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
ThriftHiveMetastore.get_part_specs_by_filter_result(List<PartitionSpec>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
ThriftHiveMetastore.get_part_specs_by_filter_result(ThriftHiveMetastore.get_part_specs_by_filter_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
Performs a deep copy on other.
ThriftHiveMetastore.get_part_specs_by_filter_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
ThriftHiveMetastore.get_partition_args(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
ThriftHiveMetastore.get_partition_args(ThriftHiveMetastore.get_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
ThriftHiveMetastore.get_partition_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
ThriftHiveMetastore.get_partition_by_name_args(ThriftHiveMetastore.get_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
ThriftHiveMetastore.get_partition_by_name_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
ThriftHiveMetastore.get_partition_by_name_result(ThriftHiveMetastore.get_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
ThriftHiveMetastore.get_partition_column_statistics_args(String, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
ThriftHiveMetastore.get_partition_column_statistics_args(ThriftHiveMetastore.get_partition_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
ThriftHiveMetastore.get_partition_column_statistics_result(ColumnStatistics, NoSuchObjectException, MetaException, InvalidInputException, InvalidObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
ThriftHiveMetastore.get_partition_column_statistics_result(ThriftHiveMetastore.get_partition_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
ThriftHiveMetastore.get_partition_names_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
ThriftHiveMetastore.get_partition_names_args(ThriftHiveMetastore.get_partition_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_ps_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_ps_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
ThriftHiveMetastore.get_partition_names_ps_args(String, String, List<String>, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
ThriftHiveMetastore.get_partition_names_ps_args(ThriftHiveMetastore.get_partition_names_ps_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_ps_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_ps_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_ps_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
ThriftHiveMetastore.get_partition_names_ps_result(List<String>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
ThriftHiveMetastore.get_partition_names_ps_result(ThriftHiveMetastore.get_partition_names_ps_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_ps_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
ThriftHiveMetastore.get_partition_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
ThriftHiveMetastore.get_partition_names_result(ThriftHiveMetastore.get_partition_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
ThriftHiveMetastore.get_partition_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
ThriftHiveMetastore.get_partition_result(ThriftHiveMetastore.get_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
ThriftHiveMetastore.get_partition_with_auth_args(String, String, List<String>, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
ThriftHiveMetastore.get_partition_with_auth_args(ThriftHiveMetastore.get_partition_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
ThriftHiveMetastore.get_partition_with_auth_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
ThriftHiveMetastore.get_partition_with_auth_result(ThriftHiveMetastore.get_partition_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
ThriftHiveMetastore.get_partitions_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
ThriftHiveMetastore.get_partitions_args(ThriftHiveMetastore.get_partitions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_expr_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_expr_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
ThriftHiveMetastore.get_partitions_by_expr_args(PartitionsByExprRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
ThriftHiveMetastore.get_partitions_by_expr_args(ThriftHiveMetastore.get_partitions_by_expr_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_expr_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_expr_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_expr_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
ThriftHiveMetastore.get_partitions_by_expr_result(PartitionsByExprResult, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
ThriftHiveMetastore.get_partitions_by_expr_result(ThriftHiveMetastore.get_partitions_by_expr_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_expr_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_filter_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_filter_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
ThriftHiveMetastore.get_partitions_by_filter_args(String, String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
ThriftHiveMetastore.get_partitions_by_filter_args(ThriftHiveMetastore.get_partitions_by_filter_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_filter_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_filter_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_filter_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
ThriftHiveMetastore.get_partitions_by_filter_result(List<Partition>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
ThriftHiveMetastore.get_partitions_by_filter_result(ThriftHiveMetastore.get_partitions_by_filter_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_filter_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
ThriftHiveMetastore.get_partitions_by_names_args(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
ThriftHiveMetastore.get_partitions_by_names_args(ThriftHiveMetastore.get_partitions_by_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
ThriftHiveMetastore.get_partitions_by_names_result(List<Partition>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
ThriftHiveMetastore.get_partitions_by_names_result(ThriftHiveMetastore.get_partitions_by_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
ThriftHiveMetastore.get_partitions_ps_args(String, String, List<String>, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
ThriftHiveMetastore.get_partitions_ps_args(ThriftHiveMetastore.get_partitions_ps_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
ThriftHiveMetastore.get_partitions_ps_result(List<Partition>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
ThriftHiveMetastore.get_partitions_ps_result(ThriftHiveMetastore.get_partitions_ps_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args(String, String, List<String>, short, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_pspec_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_pspec_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
ThriftHiveMetastore.get_partitions_pspec_args(String, String, int) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
ThriftHiveMetastore.get_partitions_pspec_args(ThriftHiveMetastore.get_partitions_pspec_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_pspec_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_pspec_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_pspec_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
ThriftHiveMetastore.get_partitions_pspec_result(List<PartitionSpec>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
ThriftHiveMetastore.get_partitions_pspec_result(ThriftHiveMetastore.get_partitions_pspec_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_pspec_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
ThriftHiveMetastore.get_partitions_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
ThriftHiveMetastore.get_partitions_result(ThriftHiveMetastore.get_partitions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_statistics_req_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_statistics_req_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
ThriftHiveMetastore.get_partitions_statistics_req_args(PartitionsStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
ThriftHiveMetastore.get_partitions_statistics_req_args(ThriftHiveMetastore.get_partitions_statistics_req_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_statistics_req_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_statistics_req_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_statistics_req_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
ThriftHiveMetastore.get_partitions_statistics_req_result(PartitionsStatsResult, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
ThriftHiveMetastore.get_partitions_statistics_req_result(ThriftHiveMetastore.get_partitions_statistics_req_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_statistics_req_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
ThriftHiveMetastore.get_partitions_with_auth_args(String, String, short, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
ThriftHiveMetastore.get_partitions_with_auth_args(ThriftHiveMetastore.get_partitions_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
ThriftHiveMetastore.get_partitions_with_auth_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
ThriftHiveMetastore.get_partitions_with_auth_result(ThriftHiveMetastore.get_partitions_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_principals_in_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_principals_in_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
ThriftHiveMetastore.get_principals_in_role_args(GetPrincipalsInRoleRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
ThriftHiveMetastore.get_principals_in_role_args(ThriftHiveMetastore.get_principals_in_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
Performs a deep copy on other.
ThriftHiveMetastore.get_principals_in_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_principals_in_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_principals_in_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
ThriftHiveMetastore.get_principals_in_role_result(GetPrincipalsInRoleResponse, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
ThriftHiveMetastore.get_principals_in_role_result(ThriftHiveMetastore.get_principals_in_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
Performs a deep copy on other.
ThriftHiveMetastore.get_principals_in_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_privilege_set_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_privilege_set_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
ThriftHiveMetastore.get_privilege_set_args(HiveObjectRef, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
ThriftHiveMetastore.get_privilege_set_args(ThriftHiveMetastore.get_privilege_set_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Performs a deep copy on other.
ThriftHiveMetastore.get_privilege_set_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_privilege_set_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_privilege_set_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
ThriftHiveMetastore.get_privilege_set_result(PrincipalPrivilegeSet, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
ThriftHiveMetastore.get_privilege_set_result(ThriftHiveMetastore.get_privilege_set_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Performs a deep copy on other.
ThriftHiveMetastore.get_privilege_set_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_grants_for_principal_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_grants_for_principal_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
ThriftHiveMetastore.get_role_grants_for_principal_args(GetRoleGrantsForPrincipalRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
ThriftHiveMetastore.get_role_grants_for_principal_args(ThriftHiveMetastore.get_role_grants_for_principal_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
Performs a deep copy on other.
ThriftHiveMetastore.get_role_grants_for_principal_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_grants_for_principal_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_grants_for_principal_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
ThriftHiveMetastore.get_role_grants_for_principal_result(GetRoleGrantsForPrincipalResponse, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
ThriftHiveMetastore.get_role_grants_for_principal_result(ThriftHiveMetastore.get_role_grants_for_principal_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
Performs a deep copy on other.
ThriftHiveMetastore.get_role_grants_for_principal_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
ThriftHiveMetastore.get_role_names_args(ThriftHiveMetastore.get_role_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_role_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
ThriftHiveMetastore.get_role_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
ThriftHiveMetastore.get_role_names_result(ThriftHiveMetastore.get_role_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_role_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
ThriftHiveMetastore.get_schema_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
ThriftHiveMetastore.get_schema_args(ThriftHiveMetastore.get_schema_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
ThriftHiveMetastore.get_schema_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
ThriftHiveMetastore.get_schema_result(ThriftHiveMetastore.get_schema_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_with_environment_context_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_with_environment_context_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
ThriftHiveMetastore.get_schema_with_environment_context_args(String, String, EnvironmentContext) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
ThriftHiveMetastore.get_schema_with_environment_context_args(ThriftHiveMetastore.get_schema_with_environment_context_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_with_environment_context_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_with_environment_context_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_with_environment_context_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
ThriftHiveMetastore.get_schema_with_environment_context_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
ThriftHiveMetastore.get_schema_with_environment_context_result(ThriftHiveMetastore.get_schema_with_environment_context_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_with_environment_context_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
ThriftHiveMetastore.get_table_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
ThriftHiveMetastore.get_table_args(ThriftHiveMetastore.get_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
ThriftHiveMetastore.get_table_column_statistics_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
ThriftHiveMetastore.get_table_column_statistics_args(ThriftHiveMetastore.get_table_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
ThriftHiveMetastore.get_table_column_statistics_result(ColumnStatistics, NoSuchObjectException, MetaException, InvalidInputException, InvalidObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
ThriftHiveMetastore.get_table_column_statistics_result(ThriftHiveMetastore.get_table_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_names_by_filter_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_names_by_filter_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
ThriftHiveMetastore.get_table_names_by_filter_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
ThriftHiveMetastore.get_table_names_by_filter_args(ThriftHiveMetastore.get_table_names_by_filter_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_names_by_filter_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_names_by_filter_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_names_by_filter_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
ThriftHiveMetastore.get_table_names_by_filter_result(List<String>, MetaException, InvalidOperationException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
ThriftHiveMetastore.get_table_names_by_filter_result(ThriftHiveMetastore.get_table_names_by_filter_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_names_by_filter_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_objects_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_objects_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
ThriftHiveMetastore.get_table_objects_by_name_args(String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
ThriftHiveMetastore.get_table_objects_by_name_args(ThriftHiveMetastore.get_table_objects_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_objects_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_objects_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_objects_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
ThriftHiveMetastore.get_table_objects_by_name_result(List<Table>, MetaException, InvalidOperationException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
ThriftHiveMetastore.get_table_objects_by_name_result(ThriftHiveMetastore.get_table_objects_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_objects_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
ThriftHiveMetastore.get_table_result(Table, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
ThriftHiveMetastore.get_table_result(ThriftHiveMetastore.get_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_statistics_req_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_statistics_req_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
ThriftHiveMetastore.get_table_statistics_req_args(TableStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
ThriftHiveMetastore.get_table_statistics_req_args(ThriftHiveMetastore.get_table_statistics_req_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_statistics_req_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_statistics_req_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_statistics_req_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
ThriftHiveMetastore.get_table_statistics_req_result(TableStatsResult, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
ThriftHiveMetastore.get_table_statistics_req_result(ThriftHiveMetastore.get_table_statistics_req_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_statistics_req_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_tables_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_tables_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
ThriftHiveMetastore.get_tables_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
ThriftHiveMetastore.get_tables_args(ThriftHiveMetastore.get_tables_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Performs a deep copy on other.
ThriftHiveMetastore.get_tables_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_tables_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_tables_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
ThriftHiveMetastore.get_tables_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
ThriftHiveMetastore.get_tables_result(ThriftHiveMetastore.get_tables_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Performs a deep copy on other.
ThriftHiveMetastore.get_tables_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_all_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_all_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
ThriftHiveMetastore.get_type_all_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
ThriftHiveMetastore.get_type_all_args(ThriftHiveMetastore.get_type_all_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Performs a deep copy on other.
ThriftHiveMetastore.get_type_all_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_all_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_all_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
ThriftHiveMetastore.get_type_all_result(Map<String, Type>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
ThriftHiveMetastore.get_type_all_result(ThriftHiveMetastore.get_type_all_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Performs a deep copy on other.
ThriftHiveMetastore.get_type_all_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
ThriftHiveMetastore.get_type_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
ThriftHiveMetastore.get_type_args(ThriftHiveMetastore.get_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Performs a deep copy on other.
ThriftHiveMetastore.get_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
ThriftHiveMetastore.get_type_result(Type, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
ThriftHiveMetastore.get_type_result(ThriftHiveMetastore.get_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Performs a deep copy on other.
ThriftHiveMetastore.get_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.getMetaConf_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.getMetaConf_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
ThriftHiveMetastore.getMetaConf_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
ThriftHiveMetastore.getMetaConf_args(ThriftHiveMetastore.getMetaConf_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
Performs a deep copy on other.
ThriftHiveMetastore.getMetaConf_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.getMetaConf_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.getMetaConf_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
ThriftHiveMetastore.getMetaConf_result(String, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
ThriftHiveMetastore.getMetaConf_result(ThriftHiveMetastore.getMetaConf_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
Performs a deep copy on other.
ThriftHiveMetastore.getMetaConf_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
ThriftHiveMetastore.grant_privileges_args(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
ThriftHiveMetastore.grant_privileges_args(ThriftHiveMetastore.grant_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
ThriftHiveMetastore.grant_privileges_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
ThriftHiveMetastore.grant_privileges_result(ThriftHiveMetastore.grant_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_revoke_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_revoke_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
ThriftHiveMetastore.grant_revoke_privileges_args(GrantRevokePrivilegeRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
ThriftHiveMetastore.grant_revoke_privileges_args(ThriftHiveMetastore.grant_revoke_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_revoke_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_revoke_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_revoke_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
ThriftHiveMetastore.grant_revoke_privileges_result(GrantRevokePrivilegeResponse, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
ThriftHiveMetastore.grant_revoke_privileges_result(ThriftHiveMetastore.grant_revoke_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_revoke_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_revoke_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_revoke_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
ThriftHiveMetastore.grant_revoke_role_args(GrantRevokeRoleRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
ThriftHiveMetastore.grant_revoke_role_args(ThriftHiveMetastore.grant_revoke_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_revoke_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_revoke_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_revoke_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
ThriftHiveMetastore.grant_revoke_role_result(GrantRevokeRoleResponse, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
ThriftHiveMetastore.grant_revoke_role_result(ThriftHiveMetastore.grant_revoke_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_revoke_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
ThriftHiveMetastore.grant_role_args(String, String, PrincipalType, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
ThriftHiveMetastore.grant_role_args(ThriftHiveMetastore.grant_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
ThriftHiveMetastore.grant_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
ThriftHiveMetastore.grant_role_result(ThriftHiveMetastore.grant_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.heartbeat_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.heartbeat_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
ThriftHiveMetastore.heartbeat_args(HeartbeatRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
ThriftHiveMetastore.heartbeat_args(ThriftHiveMetastore.heartbeat_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
Performs a deep copy on other.
ThriftHiveMetastore.heartbeat_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.heartbeat_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.heartbeat_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
ThriftHiveMetastore.heartbeat_result(NoSuchLockException, NoSuchTxnException, TxnAbortedException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
ThriftHiveMetastore.heartbeat_result(ThriftHiveMetastore.heartbeat_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
Performs a deep copy on other.
ThriftHiveMetastore.heartbeat_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.heartbeat_txn_range_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.heartbeat_txn_range_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
ThriftHiveMetastore.heartbeat_txn_range_args(HeartbeatTxnRangeRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
ThriftHiveMetastore.heartbeat_txn_range_args(ThriftHiveMetastore.heartbeat_txn_range_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
Performs a deep copy on other.
ThriftHiveMetastore.heartbeat_txn_range_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.heartbeat_txn_range_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.heartbeat_txn_range_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
ThriftHiveMetastore.heartbeat_txn_range_result(HeartbeatTxnRangeResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
ThriftHiveMetastore.heartbeat_txn_range_result(ThriftHiveMetastore.heartbeat_txn_range_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
Performs a deep copy on other.
ThriftHiveMetastore.heartbeat_txn_range_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Iface - Interface in org.apache.hadoop.hive.metastore.api
This interface is live.
ThriftHiveMetastore.isPartitionMarkedForEvent_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.isPartitionMarkedForEvent_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
ThriftHiveMetastore.isPartitionMarkedForEvent_args(String, String, Map<String, String>, PartitionEventType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
ThriftHiveMetastore.isPartitionMarkedForEvent_args(ThriftHiveMetastore.isPartitionMarkedForEvent_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
Performs a deep copy on other.
ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.isPartitionMarkedForEvent_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.isPartitionMarkedForEvent_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
ThriftHiveMetastore.isPartitionMarkedForEvent_result(boolean, MetaException, NoSuchObjectException, UnknownDBException, UnknownTableException, UnknownPartitionException, InvalidPartitionException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
ThriftHiveMetastore.isPartitionMarkedForEvent_result(ThriftHiveMetastore.isPartitionMarkedForEvent_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
Performs a deep copy on other.
ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
ThriftHiveMetastore.list_privileges_args(String, PrincipalType, HiveObjectRef) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
ThriftHiveMetastore.list_privileges_args(ThriftHiveMetastore.list_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.list_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
ThriftHiveMetastore.list_privileges_result(List<HiveObjectPrivilege>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
ThriftHiveMetastore.list_privileges_result(ThriftHiveMetastore.list_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.list_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_roles_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_roles_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
ThriftHiveMetastore.list_roles_args(String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
ThriftHiveMetastore.list_roles_args(ThriftHiveMetastore.list_roles_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Performs a deep copy on other.
ThriftHiveMetastore.list_roles_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_roles_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_roles_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
ThriftHiveMetastore.list_roles_result(List<Role>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
ThriftHiveMetastore.list_roles_result(ThriftHiveMetastore.list_roles_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Performs a deep copy on other.
ThriftHiveMetastore.list_roles_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.lock_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.lock_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
ThriftHiveMetastore.lock_args(LockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
ThriftHiveMetastore.lock_args(ThriftHiveMetastore.lock_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
Performs a deep copy on other.
ThriftHiveMetastore.lock_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.lock_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.lock_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
ThriftHiveMetastore.lock_result(LockResponse, NoSuchTxnException, TxnAbortedException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
ThriftHiveMetastore.lock_result(ThriftHiveMetastore.lock_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
Performs a deep copy on other.
ThriftHiveMetastore.lock_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.markPartitionForEvent_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.markPartitionForEvent_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
ThriftHiveMetastore.markPartitionForEvent_args(String, String, Map<String, String>, PartitionEventType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
ThriftHiveMetastore.markPartitionForEvent_args(ThriftHiveMetastore.markPartitionForEvent_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
Performs a deep copy on other.
ThriftHiveMetastore.markPartitionForEvent_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.markPartitionForEvent_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.markPartitionForEvent_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
ThriftHiveMetastore.markPartitionForEvent_result(MetaException, NoSuchObjectException, UnknownDBException, UnknownTableException, UnknownPartitionException, InvalidPartitionException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
ThriftHiveMetastore.markPartitionForEvent_result(ThriftHiveMetastore.markPartitionForEvent_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
Performs a deep copy on other.
ThriftHiveMetastore.markPartitionForEvent_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.open_txns_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.open_txns_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
ThriftHiveMetastore.open_txns_args(OpenTxnRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
ThriftHiveMetastore.open_txns_args(ThriftHiveMetastore.open_txns_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
Performs a deep copy on other.
ThriftHiveMetastore.open_txns_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.open_txns_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.open_txns_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
ThriftHiveMetastore.open_txns_result(OpenTxnsResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
ThriftHiveMetastore.open_txns_result(ThriftHiveMetastore.open_txns_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
Performs a deep copy on other.
ThriftHiveMetastore.open_txns_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_has_valid_characters_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_has_valid_characters_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
ThriftHiveMetastore.partition_name_has_valid_characters_args(List<String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
ThriftHiveMetastore.partition_name_has_valid_characters_args(ThriftHiveMetastore.partition_name_has_valid_characters_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_has_valid_characters_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_has_valid_characters_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
ThriftHiveMetastore.partition_name_has_valid_characters_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
ThriftHiveMetastore.partition_name_has_valid_characters_result(ThriftHiveMetastore.partition_name_has_valid_characters_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_spec_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_spec_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
ThriftHiveMetastore.partition_name_to_spec_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
ThriftHiveMetastore.partition_name_to_spec_args(ThriftHiveMetastore.partition_name_to_spec_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_spec_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_spec_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_spec_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
ThriftHiveMetastore.partition_name_to_spec_result(Map<String, String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
ThriftHiveMetastore.partition_name_to_spec_result(ThriftHiveMetastore.partition_name_to_spec_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_spec_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_vals_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_vals_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
ThriftHiveMetastore.partition_name_to_vals_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
ThriftHiveMetastore.partition_name_to_vals_args(ThriftHiveMetastore.partition_name_to_vals_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_vals_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_vals_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_vals_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
ThriftHiveMetastore.partition_name_to_vals_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
ThriftHiveMetastore.partition_name_to_vals_result(ThriftHiveMetastore.partition_name_to_vals_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_vals_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Processor<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor(I) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
ThriftHiveMetastore.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
ThriftHiveMetastore.Processor.abort_txn<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.abort_txn() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.abort_txn
 
ThriftHiveMetastore.Processor.add_dynamic_partitions<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_dynamic_partitions() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_dynamic_partitions
 
ThriftHiveMetastore.Processor.add_index<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_index() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_index
 
ThriftHiveMetastore.Processor.add_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition
 
ThriftHiveMetastore.Processor.add_partition_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_partition_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partition_with_environment_context
 
ThriftHiveMetastore.Processor.add_partitions<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_partitions() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions
 
ThriftHiveMetastore.Processor.add_partitions_pspec<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_partitions_pspec() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_pspec
 
ThriftHiveMetastore.Processor.add_partitions_req<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.add_partitions_req() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.add_partitions_req
 
ThriftHiveMetastore.Processor.alter_database<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_database() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_database
 
ThriftHiveMetastore.Processor.alter_function<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_function() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_function
 
ThriftHiveMetastore.Processor.alter_index<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_index() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_index
 
ThriftHiveMetastore.Processor.alter_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition
 
ThriftHiveMetastore.Processor.alter_partition_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_partition_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partition_with_environment_context
 
ThriftHiveMetastore.Processor.alter_partitions<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_partitions() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_partitions
 
ThriftHiveMetastore.Processor.alter_table<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_table() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table
 
ThriftHiveMetastore.Processor.alter_table_with_cascade<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_table_with_cascade() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_cascade
 
ThriftHiveMetastore.Processor.alter_table_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.alter_table_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.alter_table_with_environment_context
 
ThriftHiveMetastore.Processor.append_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.append_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition
 
ThriftHiveMetastore.Processor.append_partition_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.append_partition_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name
 
ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_by_name_with_environment_context
 
ThriftHiveMetastore.Processor.append_partition_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.append_partition_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.append_partition_with_environment_context
 
ThriftHiveMetastore.Processor.cancel_delegation_token<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.cancel_delegation_token() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.cancel_delegation_token
 
ThriftHiveMetastore.Processor.check_lock<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.check_lock() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.check_lock
 
ThriftHiveMetastore.Processor.commit_txn<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.commit_txn() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.commit_txn
 
ThriftHiveMetastore.Processor.compact<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.compact() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.compact
 
ThriftHiveMetastore.Processor.create_database<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_database() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_database
 
ThriftHiveMetastore.Processor.create_function<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_function() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_function
 
ThriftHiveMetastore.Processor.create_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_role
 
ThriftHiveMetastore.Processor.create_table<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_table() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table
 
ThriftHiveMetastore.Processor.create_table_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_table_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_table_with_environment_context
 
ThriftHiveMetastore.Processor.create_type<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.create_type() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.create_type
 
ThriftHiveMetastore.Processor.delete_partition_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.delete_partition_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_partition_column_statistics
 
ThriftHiveMetastore.Processor.delete_table_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.delete_table_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.delete_table_column_statistics
 
ThriftHiveMetastore.Processor.drop_database<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_database() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_database
 
ThriftHiveMetastore.Processor.drop_function<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_function() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_function
 
ThriftHiveMetastore.Processor.drop_index_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_index_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_index_by_name
 
ThriftHiveMetastore.Processor.drop_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition
 
ThriftHiveMetastore.Processor.drop_partition_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_partition_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name
 
ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_by_name_with_environment_context
 
ThriftHiveMetastore.Processor.drop_partition_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_partition_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partition_with_environment_context
 
ThriftHiveMetastore.Processor.drop_partitions_req<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_partitions_req() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_partitions_req
 
ThriftHiveMetastore.Processor.drop_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_role
 
ThriftHiveMetastore.Processor.drop_table<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_table() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table
 
ThriftHiveMetastore.Processor.drop_table_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_table_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_table_with_environment_context
 
ThriftHiveMetastore.Processor.drop_type<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.drop_type() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.drop_type
 
ThriftHiveMetastore.Processor.exchange_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.exchange_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.exchange_partition
 
ThriftHiveMetastore.Processor.fire_listener_event<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.fire_listener_event() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.fire_listener_event
 
ThriftHiveMetastore.Processor.get_aggr_stats_for<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_aggr_stats_for() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_aggr_stats_for
 
ThriftHiveMetastore.Processor.get_all_databases<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_all_databases() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_databases
 
ThriftHiveMetastore.Processor.get_all_tables<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_all_tables() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_all_tables
 
ThriftHiveMetastore.Processor.get_config_value<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_config_value() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_config_value
 
ThriftHiveMetastore.Processor.get_current_notificationEventId<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_current_notificationEventId() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_current_notificationEventId
 
ThriftHiveMetastore.Processor.get_database<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_database() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_database
 
ThriftHiveMetastore.Processor.get_databases<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_databases() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_databases
 
ThriftHiveMetastore.Processor.get_delegation_token<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_delegation_token() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_delegation_token
 
ThriftHiveMetastore.Processor.get_fields<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_fields() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields
 
ThriftHiveMetastore.Processor.get_fields_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_fields_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_fields_with_environment_context
 
ThriftHiveMetastore.Processor.get_function<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_function() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_function
 
ThriftHiveMetastore.Processor.get_functions<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_functions() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_functions
 
ThriftHiveMetastore.Processor.get_index_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_index_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_by_name
 
ThriftHiveMetastore.Processor.get_index_names<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_index_names() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_index_names
 
ThriftHiveMetastore.Processor.get_indexes<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_indexes() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_indexes
 
ThriftHiveMetastore.Processor.get_next_notification<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_next_notification() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_next_notification
 
ThriftHiveMetastore.Processor.get_open_txns<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_open_txns() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns
 
ThriftHiveMetastore.Processor.get_open_txns_info<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_open_txns_info() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_open_txns_info
 
ThriftHiveMetastore.Processor.get_part_specs_by_filter<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_part_specs_by_filter() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_part_specs_by_filter
 
ThriftHiveMetastore.Processor.get_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition
 
ThriftHiveMetastore.Processor.get_partition_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_by_name
 
ThriftHiveMetastore.Processor.get_partition_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_column_statistics
 
ThriftHiveMetastore.Processor.get_partition_names<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition_names() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names
 
ThriftHiveMetastore.Processor.get_partition_names_ps<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition_names_ps() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_names_ps
 
ThriftHiveMetastore.Processor.get_partition_with_auth<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partition_with_auth() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partition_with_auth
 
ThriftHiveMetastore.Processor.get_partitions<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions
 
ThriftHiveMetastore.Processor.get_partitions_by_expr<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_by_expr() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_expr
 
ThriftHiveMetastore.Processor.get_partitions_by_filter<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_by_filter() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_filter
 
ThriftHiveMetastore.Processor.get_partitions_by_names<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_by_names() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_by_names
 
ThriftHiveMetastore.Processor.get_partitions_ps<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_ps() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps
 
ThriftHiveMetastore.Processor.get_partitions_ps_with_auth<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_ps_with_auth() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_ps_with_auth
 
ThriftHiveMetastore.Processor.get_partitions_pspec<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_pspec() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_pspec
 
ThriftHiveMetastore.Processor.get_partitions_statistics_req<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_statistics_req() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_statistics_req
 
ThriftHiveMetastore.Processor.get_partitions_with_auth<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_partitions_with_auth() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_partitions_with_auth
 
ThriftHiveMetastore.Processor.get_principals_in_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_principals_in_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_principals_in_role
 
ThriftHiveMetastore.Processor.get_privilege_set<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_privilege_set() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_privilege_set
 
ThriftHiveMetastore.Processor.get_role_grants_for_principal<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_role_grants_for_principal() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_grants_for_principal
 
ThriftHiveMetastore.Processor.get_role_names<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_role_names() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_role_names
 
ThriftHiveMetastore.Processor.get_schema<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_schema() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema
 
ThriftHiveMetastore.Processor.get_schema_with_environment_context<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_schema_with_environment_context() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_schema_with_environment_context
 
ThriftHiveMetastore.Processor.get_table<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_table() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table
 
ThriftHiveMetastore.Processor.get_table_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_table_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_column_statistics
 
ThriftHiveMetastore.Processor.get_table_names_by_filter<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_table_names_by_filter() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_names_by_filter
 
ThriftHiveMetastore.Processor.get_table_objects_by_name<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_table_objects_by_name() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_objects_by_name
 
ThriftHiveMetastore.Processor.get_table_statistics_req<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_table_statistics_req() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_table_statistics_req
 
ThriftHiveMetastore.Processor.get_tables<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_tables() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_tables
 
ThriftHiveMetastore.Processor.get_type<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_type() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type
 
ThriftHiveMetastore.Processor.get_type_all<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.get_type_all() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.get_type_all
 
ThriftHiveMetastore.Processor.getMetaConf<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.getMetaConf() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.getMetaConf
 
ThriftHiveMetastore.Processor.grant_privileges<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.grant_privileges() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_privileges
 
ThriftHiveMetastore.Processor.grant_revoke_privileges<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.grant_revoke_privileges() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_privileges
 
ThriftHiveMetastore.Processor.grant_revoke_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.grant_revoke_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_revoke_role
 
ThriftHiveMetastore.Processor.grant_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.grant_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.grant_role
 
ThriftHiveMetastore.Processor.heartbeat<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.heartbeat() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat
 
ThriftHiveMetastore.Processor.heartbeat_txn_range<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.heartbeat_txn_range() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.heartbeat_txn_range
 
ThriftHiveMetastore.Processor.isPartitionMarkedForEvent<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.isPartitionMarkedForEvent() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.isPartitionMarkedForEvent
 
ThriftHiveMetastore.Processor.list_privileges<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.list_privileges() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_privileges
 
ThriftHiveMetastore.Processor.list_roles<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.list_roles() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.list_roles
 
ThriftHiveMetastore.Processor.lock<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.lock() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.lock
 
ThriftHiveMetastore.Processor.markPartitionForEvent<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.markPartitionForEvent() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.markPartitionForEvent
 
ThriftHiveMetastore.Processor.open_txns<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.open_txns() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.open_txns
 
ThriftHiveMetastore.Processor.partition_name_has_valid_characters<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.partition_name_has_valid_characters() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_has_valid_characters
 
ThriftHiveMetastore.Processor.partition_name_to_spec<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.partition_name_to_spec() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_spec
 
ThriftHiveMetastore.Processor.partition_name_to_vals<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.partition_name_to_vals() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.partition_name_to_vals
 
ThriftHiveMetastore.Processor.rename_partition<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.rename_partition() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.rename_partition
 
ThriftHiveMetastore.Processor.renew_delegation_token<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.renew_delegation_token() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.renew_delegation_token
 
ThriftHiveMetastore.Processor.revoke_privileges<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.revoke_privileges() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_privileges
 
ThriftHiveMetastore.Processor.revoke_role<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.revoke_role() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.revoke_role
 
ThriftHiveMetastore.Processor.set_aggr_stats_for<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.set_aggr_stats_for() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_aggr_stats_for
 
ThriftHiveMetastore.Processor.set_ugi<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.set_ugi() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.set_ugi
 
ThriftHiveMetastore.Processor.setMetaConf<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.setMetaConf() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.setMetaConf
 
ThriftHiveMetastore.Processor.show_compact<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.show_compact() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_compact
 
ThriftHiveMetastore.Processor.show_locks<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.show_locks() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.show_locks
 
ThriftHiveMetastore.Processor.unlock<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.unlock() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.unlock
 
ThriftHiveMetastore.Processor.update_partition_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.update_partition_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_partition_column_statistics
 
ThriftHiveMetastore.Processor.update_table_column_statistics<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor.update_table_column_statistics() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor.update_table_column_statistics
 
ThriftHiveMetastore.rename_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.rename_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
ThriftHiveMetastore.rename_partition_args(String, String, List<String>, Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
ThriftHiveMetastore.rename_partition_args(ThriftHiveMetastore.rename_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.rename_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.rename_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.rename_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
ThriftHiveMetastore.rename_partition_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
ThriftHiveMetastore.rename_partition_result(ThriftHiveMetastore.rename_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.rename_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.renew_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.renew_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
ThriftHiveMetastore.renew_delegation_token_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
ThriftHiveMetastore.renew_delegation_token_args(ThriftHiveMetastore.renew_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.renew_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.renew_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.renew_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
ThriftHiveMetastore.renew_delegation_token_result(long, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
ThriftHiveMetastore.renew_delegation_token_result(ThriftHiveMetastore.renew_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.renew_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
ThriftHiveMetastore.revoke_privileges_args(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
ThriftHiveMetastore.revoke_privileges_args(ThriftHiveMetastore.revoke_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.revoke_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
ThriftHiveMetastore.revoke_privileges_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
ThriftHiveMetastore.revoke_privileges_result(ThriftHiveMetastore.revoke_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.revoke_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
ThriftHiveMetastore.revoke_role_args(String, String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
ThriftHiveMetastore.revoke_role_args(ThriftHiveMetastore.revoke_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Performs a deep copy on other.
ThriftHiveMetastore.revoke_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
ThriftHiveMetastore.revoke_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
ThriftHiveMetastore.revoke_role_result(ThriftHiveMetastore.revoke_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Performs a deep copy on other.
ThriftHiveMetastore.revoke_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.set_aggr_stats_for_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.set_aggr_stats_for_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
ThriftHiveMetastore.set_aggr_stats_for_args(SetPartitionsStatsRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
ThriftHiveMetastore.set_aggr_stats_for_args(ThriftHiveMetastore.set_aggr_stats_for_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
Performs a deep copy on other.
ThriftHiveMetastore.set_aggr_stats_for_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.set_aggr_stats_for_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.set_aggr_stats_for_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
ThriftHiveMetastore.set_aggr_stats_for_result(boolean, NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
ThriftHiveMetastore.set_aggr_stats_for_result(ThriftHiveMetastore.set_aggr_stats_for_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
Performs a deep copy on other.
ThriftHiveMetastore.set_aggr_stats_for_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.set_ugi_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.set_ugi_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
ThriftHiveMetastore.set_ugi_args(String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
ThriftHiveMetastore.set_ugi_args(ThriftHiveMetastore.set_ugi_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
Performs a deep copy on other.
ThriftHiveMetastore.set_ugi_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.set_ugi_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.set_ugi_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
ThriftHiveMetastore.set_ugi_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
ThriftHiveMetastore.set_ugi_result(ThriftHiveMetastore.set_ugi_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
Performs a deep copy on other.
ThriftHiveMetastore.set_ugi_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.setMetaConf_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.setMetaConf_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
ThriftHiveMetastore.setMetaConf_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
ThriftHiveMetastore.setMetaConf_args(ThriftHiveMetastore.setMetaConf_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
Performs a deep copy on other.
ThriftHiveMetastore.setMetaConf_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.setMetaConf_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.setMetaConf_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
ThriftHiveMetastore.setMetaConf_result(MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
ThriftHiveMetastore.setMetaConf_result(ThriftHiveMetastore.setMetaConf_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
Performs a deep copy on other.
ThriftHiveMetastore.setMetaConf_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.show_compact_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.show_compact_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
ThriftHiveMetastore.show_compact_args(ShowCompactRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
ThriftHiveMetastore.show_compact_args(ThriftHiveMetastore.show_compact_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
Performs a deep copy on other.
ThriftHiveMetastore.show_compact_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.show_compact_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.show_compact_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
ThriftHiveMetastore.show_compact_result(ShowCompactResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
ThriftHiveMetastore.show_compact_result(ThriftHiveMetastore.show_compact_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
Performs a deep copy on other.
ThriftHiveMetastore.show_compact_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.show_locks_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.show_locks_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
ThriftHiveMetastore.show_locks_args(ShowLocksRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
ThriftHiveMetastore.show_locks_args(ThriftHiveMetastore.show_locks_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
Performs a deep copy on other.
ThriftHiveMetastore.show_locks_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.show_locks_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.show_locks_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
ThriftHiveMetastore.show_locks_result(ShowLocksResponse) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
ThriftHiveMetastore.show_locks_result(ThriftHiveMetastore.show_locks_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
Performs a deep copy on other.
ThriftHiveMetastore.show_locks_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.unlock_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.unlock_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
ThriftHiveMetastore.unlock_args(UnlockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
ThriftHiveMetastore.unlock_args(ThriftHiveMetastore.unlock_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
Performs a deep copy on other.
ThriftHiveMetastore.unlock_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.unlock_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.unlock_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
ThriftHiveMetastore.unlock_result(NoSuchLockException, TxnOpenException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
ThriftHiveMetastore.unlock_result(ThriftHiveMetastore.unlock_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
Performs a deep copy on other.
ThriftHiveMetastore.unlock_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.update_partition_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.update_partition_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
ThriftHiveMetastore.update_partition_column_statistics_args(ColumnStatistics) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
ThriftHiveMetastore.update_partition_column_statistics_args(ThriftHiveMetastore.update_partition_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.update_partition_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.update_partition_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.update_partition_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
ThriftHiveMetastore.update_partition_column_statistics_result(boolean, NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
ThriftHiveMetastore.update_partition_column_statistics_result(ThriftHiveMetastore.update_partition_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.update_partition_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.update_table_column_statistics_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.update_table_column_statistics_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
ThriftHiveMetastore.update_table_column_statistics_args(ColumnStatistics) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
ThriftHiveMetastore.update_table_column_statistics_args(ThriftHiveMetastore.update_table_column_statistics_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
Performs a deep copy on other.
ThriftHiveMetastore.update_table_column_statistics_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.update_table_column_statistics_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.update_table_column_statistics_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
ThriftHiveMetastore.update_table_column_statistics_result(boolean, NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
ThriftHiveMetastore.update_table_column_statistics_result(ThriftHiveMetastore.update_table_column_statistics_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
Performs a deep copy on other.
ThriftHiveMetastore.update_table_column_statistics_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHttpCLIService - Class in org.apache.hive.service.cli.thrift
 
ThriftHttpCLIService(CLIService) - Constructor for class org.apache.hive.service.cli.thrift.ThriftHttpCLIService
 
ThriftHttpServlet - Class in org.apache.hive.service.cli.thrift
ThriftHttpServlet
ThriftHttpServlet(TProcessor, TProtocolFactory, String, UserGroupInformation, UserGroupInformation) - Constructor for class org.apache.hive.service.cli.thrift.ThriftHttpServlet
 
ThriftObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector
 
ThriftObjectInspectorUtils() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ThriftObjectInspectorUtils
 
thriftReaderFname - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
thriftRWParams - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
ThriftTestObj - Class in org.apache.hadoop.hive.serde.test
 
ThriftTestObj() - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
ThriftTestObj(int, String, List<InnerStruct>) - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
ThriftTestObj(ThriftTestObj) - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
Performs a deep copy on other.
ThriftTestObj._Fields - Enum in org.apache.hadoop.hive.serde.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
Always use the ObjectInspectorFactory to create new ObjectInspector objects, instead of directly creating an instance of this class.
ThriftUnionObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector
 
thriftWriterFname - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
Throttle - Class in org.apache.hadoop.hive.ql.exec.mr
Intelligence to make clients wait if the cluster is in a bad state.
throwIfExceedsTenToThirtyEight() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Used to check overflows.
Throws() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TI16Column - Class in org.apache.hive.service.cli.thrift
 
TI16Column() - Constructor for class org.apache.hive.service.cli.thrift.TI16Column
 
TI16Column(List<Short>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TI16Column
 
TI16Column(TI16Column) - Constructor for class org.apache.hive.service.cli.thrift.TI16Column
Performs a deep copy on other.
TI16Column._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TI16Value - Class in org.apache.hive.service.cli.thrift
 
TI16Value() - Constructor for class org.apache.hive.service.cli.thrift.TI16Value
 
TI16Value(TI16Value) - Constructor for class org.apache.hive.service.cli.thrift.TI16Value
Performs a deep copy on other.
TI16Value._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TI32Column - Class in org.apache.hive.service.cli.thrift
 
TI32Column() - Constructor for class org.apache.hive.service.cli.thrift.TI32Column
 
TI32Column(List<Integer>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TI32Column
 
TI32Column(TI32Column) - Constructor for class org.apache.hive.service.cli.thrift.TI32Column
Performs a deep copy on other.
TI32Column._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TI32Value - Class in org.apache.hive.service.cli.thrift
 
TI32Value() - Constructor for class org.apache.hive.service.cli.thrift.TI32Value
 
TI32Value(TI32Value) - Constructor for class org.apache.hive.service.cli.thrift.TI32Value
Performs a deep copy on other.
TI32Value._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TI64Column - Class in org.apache.hive.service.cli.thrift
 
TI64Column() - Constructor for class org.apache.hive.service.cli.thrift.TI64Column
 
TI64Column(List<Long>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TI64Column
 
TI64Column(TI64Column) - Constructor for class org.apache.hive.service.cli.thrift.TI64Column
Performs a deep copy on other.
TI64Column._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TI64Value - Class in org.apache.hive.service.cli.thrift
 
TI64Value() - Constructor for class org.apache.hive.service.cli.thrift.TI64Value
 
TI64Value(TI64Value) - Constructor for class org.apache.hive.service.cli.thrift.TI64Value
Performs a deep copy on other.
TI64Value._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TIME_TO_SUBMIT - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TIMESTAMP - Static variable in class org.apache.hive.hcatalog.data.DataType
 
TIMESTAMP_FORMATS - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
TIMESTAMP_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
TIMESTAMP_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
TIMESTAMP_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
TIMESTAMP = 9;
TimestampColAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
TimestampColAddIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeColumn
 
TimestampColAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeColumn
 
TimestampColAddIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
TimestampColAddIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeScalar
 
TimestampColAddIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalDayTimeScalar
 
TimestampColAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
TimestampColAddIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
TimestampColAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthColumn
 
TimestampColAddIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
TimestampColAddIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
TimestampColAddIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColAddIntervalYearMonthScalar
 
TimestampColEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualDoubleScalar
 
TimestampColEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualDoubleScalar
 
TimestampColEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualLongScalar
 
TimestampColEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualLongScalar
 
TimestampColEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColEqualTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualTimestampScalar
 
TimestampColEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColEqualTimestampScalar
 
TimestampColGreaterDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColGreaterDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterDoubleScalar
 
TimestampColGreaterDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterDoubleScalar
 
TimestampColGreaterEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColGreaterEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualDoubleScalar
 
TimestampColGreaterEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualDoubleScalar
 
TimestampColGreaterEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColGreaterEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualLongScalar
 
TimestampColGreaterEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualLongScalar
 
TimestampColGreaterEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColGreaterEqualTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualTimestampScalar
 
TimestampColGreaterEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterEqualTimestampScalar
 
TimestampColGreaterLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColGreaterLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterLongScalar
 
TimestampColGreaterLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterLongScalar
 
TimestampColGreaterTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColGreaterTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterTimestampScalar
 
TimestampColGreaterTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColGreaterTimestampScalar
 
TimestampColLessDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColLessDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessDoubleScalar
 
TimestampColLessDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessDoubleScalar
 
TimestampColLessEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColLessEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualDoubleScalar
 
TimestampColLessEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualDoubleScalar
 
TimestampColLessEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColLessEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualLongScalar
 
TimestampColLessEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualLongScalar
 
TimestampColLessEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColLessEqualTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualTimestampScalar
 
TimestampColLessEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessEqualTimestampScalar
 
TimestampColLessLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColLessLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessLongScalar
 
TimestampColLessLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessLongScalar
 
TimestampColLessTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColLessTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessTimestampScalar
 
TimestampColLessTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColLessTimestampScalar
 
TimestampColNotEqualDoubleScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColNotEqualDoubleScalar(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualDoubleScalar
 
TimestampColNotEqualDoubleScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualDoubleScalar
 
TimestampColNotEqualLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareScalar.txt, which covers comparison expressions between a timestamp column and a long or double scalar.
TimestampColNotEqualLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualLongScalar
 
TimestampColNotEqualLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualLongScalar
 
TimestampColNotEqualTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampColumnCompareTimestampScalar.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampColNotEqualTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualTimestampScalar
 
TimestampColNotEqualTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColNotEqualTimestampScalar
 
TimestampColSubtractDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
TimestampColSubtractDateColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
TimestampColSubtractDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateColumn
 
TimestampColSubtractDateScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
TimestampColSubtractDateScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
TimestampColSubtractDateScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractDateScalar
 
TimestampColSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
TimestampColSubtractIntervalDayTimeColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeColumn
 
TimestampColSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeColumn
 
TimestampColSubtractIntervalDayTimeScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
TimestampColSubtractIntervalDayTimeScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeScalar
 
TimestampColSubtractIntervalDayTimeScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalDayTimeScalar
 
TimestampColSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert.txt, which covers binary arithmetic expressions between columns.
TimestampColSubtractIntervalYearMonthColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
TimestampColSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthColumn
 
TimestampColSubtractIntervalYearMonthScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ColumnArithmeticScalarWithConvert.txt, which covers binary arithmetic expressions between a column and a scalar.
TimestampColSubtractIntervalYearMonthScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
TimestampColSubtractIntervalYearMonthScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractIntervalYearMonthScalar
 
TimestampColSubtractTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval column.
TimestampColSubtractTimestampColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampColumn
 
TimestampColSubtractTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampColumn
 
TimestampColSubtractTimestampScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIColumnArithmeticDTIScalarNoConvert.txt, which covers arithmetic expressions between a datetime/interval column and a datetime/interval scalar.
TimestampColSubtractTimestampScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampScalar
 
TimestampColSubtractTimestampScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampColSubtractTimestampScalar
 
TimestampColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for Timestamp columns.
timestampFormats - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyObjectInspectorParametersImpl
 
timestampFormats - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
timestampLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
timestampLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TimestampObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
timestampParser - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyTimestampObjectInspector
 
TimestampParser - Class in org.apache.hive.common.util
Timestamp parser using Joda DateTimeFormatter.
TimestampParser() - Constructor for class org.apache.hive.common.util.TimestampParser
 
TimestampParser(TimestampParser) - Constructor for class org.apache.hive.common.util.TimestampParser
 
TimestampParser(List<String>) - Constructor for class org.apache.hive.common.util.TimestampParser
 
TimestampParser(String[]) - Constructor for class org.apache.hive.common.util.TimestampParser
 
TimestampParser.MillisDateFormatParser - Class in org.apache.hive.common.util
DateTimeParser to parse the date string as the millis since Unix epoch
TimestampParser.MillisDateFormatParser() - Constructor for class org.apache.hive.common.util.TimestampParser.MillisDateFormatParser
 
timestampResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIMinus
 
timestampResult - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDTIPlus
 
TimestampScalarAddIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
TimestampScalarAddIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalDayTimeColumn
 
TimestampScalarAddIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalDayTimeColumn
 
TimestampScalarAddIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert.txt.
TimestampScalarAddIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
TimestampScalarAddIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarAddIntervalYearMonthColumn
 
TimestampScalarEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarEqualTimestampColumn
 
TimestampScalarEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarEqualTimestampColumn
 
TimestampScalarGreaterEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarGreaterEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterEqualTimestampColumn
 
TimestampScalarGreaterEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterEqualTimestampColumn
 
TimestampScalarGreaterTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarGreaterTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterTimestampColumn
 
TimestampScalarGreaterTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarGreaterTimestampColumn
 
TimestampScalarLessEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarLessEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessEqualTimestampColumn
 
TimestampScalarLessEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessEqualTimestampColumn
 
TimestampScalarLessTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarLessTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessTimestampColumn
 
TimestampScalarLessTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarLessTimestampColumn
 
TimestampScalarNotEqualTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template TimestampScalarCompareTimestampColumn.txt, which covers comparison expressions between a timestamp column and a timestamp scalar.
TimestampScalarNotEqualTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarNotEqualTimestampColumn
 
TimestampScalarNotEqualTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarNotEqualTimestampColumn
 
TimestampScalarSubtractDateColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template ScalarArithmeticColumnWithConvert.txt.
TimestampScalarSubtractDateColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
TimestampScalarSubtractDateColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractDateColumn
 
TimestampScalarSubtractIntervalDayTimeColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
TimestampScalarSubtractIntervalDayTimeColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalDayTimeColumn
 
TimestampScalarSubtractIntervalDayTimeColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalDayTimeColumn
 
TimestampScalarSubtractIntervalYearMonthColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert.txt.
TimestampScalarSubtractIntervalYearMonthColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
TimestampScalarSubtractIntervalYearMonthColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractIntervalYearMonthColumn
 
TimestampScalarSubtractTimestampColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
Generated from template DTIScalarArithmeticDTIColumnNoConvert.txt, which covers arithmetic expressions between a datetime/interval scalar and a datetime/interval column.
TimestampScalarSubtractTimestampColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractTimestampColumn
 
TimestampScalarSubtractTimestampColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.TimestampScalarSubtractTimestampColumn
 
TIMESTAMPSTATISTICS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
timestampTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
timestampTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
TimestampUtils - Class in org.apache.hadoop.hive.ql.exec.vector
 
TimestampUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
timestampWritable - Variable in class org.apache.hadoop.hive.serde2.fast.DeserializeRead.ReadTimestampResults
 
TimestampWritable - Class in org.apache.hadoop.hive.serde2.io
TimestampWritable Writable equivalent of java.sq.Timestamp Timestamps are of the format YYYY-MM-DD HH:MM:SS.[fff...] We encode Unix timestamp in seconds in 4 bytes, using the MSB to signify whether the timestamp has a fractional portion.
TimestampWritable() - Constructor for class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
TimestampWritable(byte[], int) - Constructor for class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
TimestampWritable(TimestampWritable) - Constructor for class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
TimestampWritable(Timestamp) - Constructor for class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
timeToDate(long) - Static method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
TINY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
TINYINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
TinyintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TinyintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TinyintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TinyintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TinyintLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TMapTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TMapTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
TMapTypeEntry(int, int) - Constructor for class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
TMapTypeEntry(TMapTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TMapTypeEntry
Performs a deep copy on other.
TMapTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tmpOutputFile - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Temporary file name used to store results of non-Hive commands (e.g., set, dfs) and HiveServer.fetch*() function will read results from this file
tmpPath - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
tmpPathFixed - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
tmpPathFixedConcatenate - Variable in class org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator
 
toArray() - Method in class org.apache.hadoop.hive.ql.exec.persistence.FlatRowContainer
 
toArray(RecordIdentifier, Object[]) - Static method in class org.apache.hadoop.hive.ql.io.RecordIdentifier.StructInfo
Copies relevant fields from ri to struct
toBigDecimal() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Converts this object to BigDecimal.
toBigIntegerSlow() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Convert this object to BigInteger.
toBigIntegerSlow() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Convert this object to BigInteger.
toBinary() - Method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
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
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
toBuilder() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
toCachedEval(ExprNodeEvaluator) - Static method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
Should be called before eval is initialized
toCachedEvals(ExprNodeEvaluator[]) - Static method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
 
toCause(List<String>) - Static method in exception org.apache.hive.service.cli.HiveSQLException
Converts a flattened list of texts including the stack trace and the stack traces of the nested causes into a Throwable object.
toColumns(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
toColumnValue(TColumnValue) - Static method in class org.apache.hive.service.cli.ColumnValue
 
toCompactString(int[][]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
toDescription() - Method in class org.apache.hadoop.hive.conf.Validator.PatternSet
 
toDescription() - Method in class org.apache.hadoop.hive.conf.Validator.RangeValidator
 
toDescription() - Method in class org.apache.hadoop.hive.conf.Validator.RatioValidator
 
toDescription() - Method in class org.apache.hadoop.hive.conf.Validator.StringSet
 
toDescription() - Method in class org.apache.hadoop.hive.conf.Validator.TimeValidator
 
toDescription() - Method in interface org.apache.hadoop.hive.conf.Validator
 
toFilterPredicate() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Translate the search argument to the filter predicate parquet used
toFormalString() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Returns the formal string representation of this value.
toFormalString() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Returns the formal string representation of this value.
toFormalString() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Returns the formal string representation of this value.
toFunctionResource(List<ResourceUri>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
toHiveKey(Object, int, Integer) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
toInt(String) - Static method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
toJavaSQLType() - Method in enum org.apache.hive.service.cli.Type
 
toJdbcTableType(String) - Static method in class org.apache.hive.jdbc.HiveDatabaseMetaData
Translate hive table types into jdbc table types.
TOK_ADMIN_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ADMIN_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ADMIN_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ADMIN_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERDATABASE_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERDATABASE_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERDATABASE_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERDATABASE_OWNER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERINDEX_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERINDEX_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERINDEX_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERINDEX_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_BUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_CLUSTER_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_CLUSTER_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_CLUSTER_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_CLUSTER_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_COMPACT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_EXCHANGEPARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_EXCHANGEPARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_EXCHANGEPARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_EXCHANGEPARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_MERGEFILES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_MERGEFILES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_MERGEFILES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_MERGEFILES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_PARTCOLTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_PARTCOLTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_PARTCOLTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_PARTCOLTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_RENAMECOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_RENAMECOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_RENAMECOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_RENAMECOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_RENAMEPART - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_RENAMEPART - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_RENAMEPART - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_RENAMEPART - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_SKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_SKEWED_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SKEWED_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_SKEWED_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_SKEWED_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERTABLE_UPDATECOLSTATS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_UPDATECOLSTATS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERTABLE_UPDATECOLSTATS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERTABLE_UPDATECOLSTATS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW_DROPPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ALTERVIEW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ALTERVIEW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ALTERVIEW_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ANONYMOUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ANONYMOUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ANONYMOUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ANONYMOUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_async - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_BINARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_bool - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_byte - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CASCADE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_cocoa_prefix - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_COL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_COL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_COL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_COL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_const - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_include - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_type - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CREATEVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CREATEVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CREATEVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CROSSJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CROSSJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CROSSJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CROSSJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_csharp_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_CTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_CUBE_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CUBE_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_CUBE_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_CUBE_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATABASELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATABASELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATABASELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATABASELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATELITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATELITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATELITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATELITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DB_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DB_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DB_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DB_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DECIMAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DELETE_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DELETE_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DELETE_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DELETE_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DESCDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DESCDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DESCDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_double - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_double_constant - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPMACRO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_enum - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_exception - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_EXPLAIN_SQ_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_EXPLAIN_SQ_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_EXPLAIN_SQ_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_EXPLAIN_SQ_REWRITE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_EXPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_extends - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FILEFORMAT_GENERIC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FILEFORMAT_GENERIC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FILEFORMAT_GENERIC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FILEFORMAT_GENERIC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GRANT_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GRANT_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GRANT_OPTION_FOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GRANT_WITH_ADMIN_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_WITH_ADMIN_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GRANT_WITH_ADMIN_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GRANT_WITH_ADMIN_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GROUPING_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUPING_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GROUPING_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GROUPING_SETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_GROUPING_SETS_EXPRESSION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUPING_SETS_EXPRESSION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_GROUPING_SETS_EXPRESSION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_GROUPING_SETS_EXPRESSION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_i16 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_i32 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_i64 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_IGNOREPROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_IGNOREPROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_IGNOREPROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_IGNOREPROTECTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_IMPORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_include - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INSERT_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INSERT_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INSERT_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INSERT_INTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_int_constant - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_INTERVAL_DAY_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_DAY_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_DAY_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_DAY_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_DAY_TIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_DAY_TIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_DAY_TIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_DAY_TIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_DAY_TIME_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_DAY_TIME_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_DAY_TIME_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_DAY_TIME_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_HOUR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_HOUR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_HOUR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_HOUR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_MINUTE_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_MINUTE_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_MINUTE_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_MINUTE_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_SECOND_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_SECOND_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_SECOND_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_SECOND_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_YEAR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_YEAR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_YEAR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_YEAR_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_YEAR_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_YEAR_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_YEAR_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_YEAR_MONTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_INTERVAL_YEAR_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INTERVAL_YEAR_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_INTERVAL_YEAR_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_INTERVAL_YEAR_MONTH_LITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_JAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_java_package - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LATERAL_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LATERAL_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LATERAL_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LATERAL_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LATERAL_VIEW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LATERAL_VIEW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LATERAL_VIEW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LATERAL_VIEW_OUTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LEFTSEMIJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LEFTSEMIJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LEFTSEMIJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LEFTSEMIJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LENGTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LENGTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LENGTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LENGTH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_list - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_literal - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_LOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_LOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_LOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_map - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_NOT_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_NOT_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_NOT_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_NOT_CLUSTERED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_NOT_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_NOT_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_NOT_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_NOT_SORTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_optional - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_ORDERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ORDERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ORDERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ORDERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ORREPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ORREPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ORREPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ORREPLACE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PARTITIONINGSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTITIONINGSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PARTITIONINGSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PARTITIONINGSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PERCENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_perl_package - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_php_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_DELETE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_PTBLFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PTBLFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_PTBLFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_PTBLFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_py_module - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_QUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_QUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_QUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_QUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RELOADFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RELOADFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RELOADFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RELOADFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_REPLICATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_required - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_RESOURCE_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RESOURCE_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RESOURCE_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RESOURCE_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RESOURCE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RESOURCE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RESOURCE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RESOURCE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RESOURCE_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RESOURCE_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RESOURCE_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RESOURCE_URI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RESTRICT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ROLLUP_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ROLLUP_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ROLLUP_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ROLLUP_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_ROWCOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ROWCOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_ROWCOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_ROWCOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_ruby_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_senum - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SERVER_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERVER_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SERVER_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SERVER_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_service - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_set - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SET_COLUMNS_CLAUSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SET_COLUMNS_CLAUSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SET_COLUMNS_CLAUSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SET_COLUMNS_CLAUSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_COMPACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_ROLE_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_ROLE_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_ROLE_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_ROLE_PRINCIPALS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_ROLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_SET_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_SET_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_SET_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_SET_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOW_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWCOLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWCOLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWCOLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWCOLUMNS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWCONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWCONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWCONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWCONF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWDBLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWDBLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWDBLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWDBLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SKEWED_LOCATION_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SKEWED_LOCATION_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SKEWED_LOCATION_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SKEWED_LOCATION_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SKEWED_LOCATION_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SKEWED_LOCATION_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SKEWED_LOCATION_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SKEWED_LOCATION_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SKEWED_LOCATIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SKEWED_LOCATIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SKEWED_LOCATIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SKEWED_LOCATIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_skip - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_slist - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_smalltalk_category - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_smalltalk_prefix - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SORTBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SORTBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SORTBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SORTBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_st_identifier - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_STOREDASDIRS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STOREDASDIRS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STOREDASDIRS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STOREDASDIRS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_string - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_STRINGLITERALSEQUENCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STRINGLITERALSEQUENCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STRINGLITERALSEQUENCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STRINGLITERALSEQUENCE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_struct - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_SUBQUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SUBQUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SUBQUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SUBQUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SUBQUERY_EXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SUBQUERY_EXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SUBQUERY_EXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SUBQUERY_EXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SUBQUERY_OP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SUBQUERY_OP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SUBQUERY_OP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SUBQUERY_OP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SUBQUERY_OP_NOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SUBQUERY_OP_NOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SUBQUERY_OP_NOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SUBQUERY_OP_NOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SUBQUERY_OP_NOTIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SUBQUERY_OP_NOTIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SUBQUERY_OP_NOTIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SUBQUERY_OP_NOTIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_SWITCHDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SWITCHDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_SWITCHDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_SWITCHDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABALIAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABALIAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABALIAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABALIAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOLVALUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLVALUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOLVALUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOLVALUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOLVALUE_PAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLVALUE_PAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOLVALUE_PAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOLVALUE_PAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABCOLVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABCOLVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABCOLVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLE_OR_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLE_OR_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLE_OR_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLE_OR_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLE_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEBUCKETSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEBUCKETSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEBUCKETSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEBUCKETSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLEROWFORMATNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLEROWFORMATNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLEROWFORMATNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLESKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLESKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLESKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLESKEWED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABLESPLITSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLESPLITSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABLESPLITSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABLESPLITSAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABSRC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABSRC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABSRC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABSRC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TEMPORARY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_throws - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TIMESTAMPLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TIMESTAMPLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TIMESTAMPLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TIMESTAMPLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_TRUNCATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TRUNCATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_TRUNCATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_TRUNCATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_typedef - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_UNIONALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNIONALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNIONALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNIONALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UNIONDISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNIONDISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNIONDISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNIONDISTINCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UNLOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNLOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNLOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNLOCKDB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_UPDATE_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UPDATE_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_UPDATE_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_UPDATE_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_URI_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_URI_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_URI_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_URI_TYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VALUE_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VALUE_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VALUE_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VALUE_ROW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VALUES_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VALUES_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VALUES_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VALUES_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VARCHAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VIEWPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VIEWPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VIEWPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VIEWPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VIRTUAL_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VIRTUAL_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VIRTUAL_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VIRTUAL_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_VIRTUAL_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_VIRTUAL_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_VIRTUAL_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_VIRTUAL_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_void - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_WINDOWDEF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_WINDOWDEF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_WINDOWDEF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_WINDOWDEF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_WINDOWRANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_WINDOWRANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_WINDOWRANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_WINDOWRANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_WINDOWSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_WINDOWSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_WINDOWSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_WINDOWSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
TOK_WINDOWVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_WINDOWVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
TOK_WINDOWVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
TOK_WINDOWVALUES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
tok_xsd_all - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_xsd_attrs - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_xsd_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_xsd_nillable - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_xsd_optional - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
token - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Current token.
Token - Class in org.apache.hadoop.hive.serde2.dynamic_type
Describes the input token stream.
Token() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.Token
 
TOKEN_FILE_ARG_PLACEHOLDER - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
TOKEN_FILE_ARG_PLACEHOLDER_TEZ - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
token_source - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Generated Token Manager.
tokenImage - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
tokenImage - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
Literal token values.
TokenMgrError - Error in org.apache.hadoop.hive.serde2.dynamic_type
 
TokenMgrError() - Constructor for error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
 
TokenMgrError(String, int) - Constructor for error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
 
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.hadoop.hive.serde2.dynamic_type.TokenMgrError
 
tokenNames - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
tokenNames - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TokenStoreDelegationTokenSecretManager - Class in org.apache.hadoop.hive.thrift
Extension of DelegationTokenSecretManager to support alternative to default in-memory token management for fail-over and clustering through plug-able token store (ZooKeeper etc.).
TokenStoreDelegationTokenSecretManager(long, long, long, long, DelegationTokenStore) - Constructor for class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager
 
TokenStoreDelegationTokenSecretManager.ExpiredTokenRemover - Class in org.apache.hadoop.hive.thrift
Cloned from AbstractDelegationTokenSecretManager to deal with private access restriction (there would not be an need to clone the remove thread if the remove logic was protected/extensible).
TokenStoreDelegationTokenSecretManager.ExpiredTokenRemover() - Constructor for class org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager.ExpiredTokenRemover
 
toKryo() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Serialize the SARG as a kyro object and return the base64 string.
toLazyObject(int, byte[]) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloCompositeRowId
Create an initialize a LazyObject with the given bytes for the given fieldID.
toLazyObject(int, byte[]) - Method in class org.apache.hadoop.hive.hbase.HBaseCompositeKey
Create an initialize a LazyObject with the given bytes for the given fieldID.
toLazyObject(int, byte[]) - Method in class org.apache.hadoop.hive.hbase.struct.HBaseStructValue
Create an initialize a LazyObject with the given bytes for the given fieldID.
TOLERATE_CORRUPTIONS_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
toMappingString(String, String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
toMessage(ErrorMsg, Object) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
tooManyAborts - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
TooManyAccumuloColumnsException - Exception in org.apache.hadoop.hive.accumulo.serde
 
TooManyAccumuloColumnsException() - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyAccumuloColumnsException
 
TooManyAccumuloColumnsException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyAccumuloColumnsException
 
TooManyAccumuloColumnsException(String) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyAccumuloColumnsException
 
TooManyAccumuloColumnsException(Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyAccumuloColumnsException
 
TooManyHiveColumnsException - Exception in org.apache.hadoop.hive.accumulo.serde
 
TooManyHiveColumnsException() - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyHiveColumnsException
 
TooManyHiveColumnsException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyHiveColumnsException
 
TooManyHiveColumnsException(String) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyHiveColumnsException
 
TooManyHiveColumnsException(Throwable) - Constructor for exception org.apache.hadoop.hive.accumulo.serde.TooManyHiveColumnsException
 
toPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.partition.spec.CompositePartitionSpecProxy
 
toPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionListComposingSpecProxy
 
toPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecProxy
Conversion to a org.apache.hadoop.hive.metastore.api.PartitionSpec sequence.
toPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.partition.spec.PartitionSpecWithSharedSDProxy
 
TOpenSessionReq - Class in org.apache.hive.service.cli.thrift
 
TOpenSessionReq() - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
TOpenSessionReq(TProtocolVersion) - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
TOpenSessionReq(TOpenSessionReq) - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionReq
Performs a deep copy on other.
TOpenSessionReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TOpenSessionResp - Class in org.apache.hive.service.cli.thrift
 
TOpenSessionResp() - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
TOpenSessionResp(TStatus, TProtocolVersion) - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
TOpenSessionResp(TOpenSessionResp) - Constructor for class org.apache.hive.service.cli.thrift.TOpenSessionResp
Performs a deep copy on other.
TOpenSessionResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TOperationHandle - Class in org.apache.hive.service.cli.thrift
 
TOperationHandle() - Constructor for class org.apache.hive.service.cli.thrift.TOperationHandle
 
TOperationHandle(THandleIdentifier, TOperationType, boolean) - Constructor for class org.apache.hive.service.cli.thrift.TOperationHandle
 
TOperationHandle(TOperationHandle) - Constructor for class org.apache.hive.service.cli.thrift.TOperationHandle
Performs a deep copy on other.
TOperationHandle._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TOperationState - Enum in org.apache.hive.service.cli.thrift
 
TOperationType - Enum in org.apache.hive.service.cli.thrift
 
topN - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
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.
topOps - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
topOps - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
toReadEntity(String) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
toReadEntity(Path) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
toRel(RelOptTable.ToRelContext) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
toResponse(Exception) - Method in class org.apache.hive.hcatalog.templeton.CatchallExceptionMapper
 
toResponse(SimpleWebException) - Method in class org.apache.hive.hcatalog.templeton.SimpleExceptionMapper
 
toSetting(HiveAccumuloColumnMapping, IndexSearchCondition) - Method in class org.apache.hadoop.hive.accumulo.predicate.AccumuloPredicateHandler
Create an IteratorSetting for the right qualifier, constant, CompareOpt, and PrimitiveCompare type.
toSQLException(String, CommandProcessorResponse) - Method in class org.apache.hive.service.cli.operation.Operation
 
toString() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow.ColumnTuple
 
toString() - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
toString() - Method in class org.apache.hadoop.hive.accumulo.columns.ColumnMapper
 
toString() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloColumnMapping
 
toString() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
toString() - Method in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloRowIdColumnMapping
 
toString() - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
toString() - Method in class org.apache.hadoop.hive.ant.DistinctElementsClassPath
Returns a textual representation of the path after removing the duplicate files from the original Path.
toString() - Method in class org.apache.hadoop.hive.common.DiskRange
 
toString() - Method in class org.apache.hadoop.hive.common.jsonexplain.tez.Attr
 
toString() - Method in class org.apache.hadoop.hive.common.ObjectPair
 
toString() - Method in class org.apache.hadoop.hive.common.type.Decimal128
 
toString() - Method in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
toString() - Method in class org.apache.hadoop.hive.common.type.HiveChar
 
toString() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
toString() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
toString() - Method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
toString() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
 
toString() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
 
toString() - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
toString() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
toString() - Method in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer
 
toString() - Method in class org.apache.hadoop.hive.contrib.udtf.example.GenericUDTFExplode2
 
toString() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Generate a suitable string representation.
toString() - Method in class org.apache.hadoop.hive.hbase.HBaseScanRange
 
toString() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDe
 
toString() - Method in class org.apache.hadoop.hive.hbase.HBaseSerDeParameters
 
toString() - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
toString() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionEvent
 
toString() - Method in class org.apache.hadoop.hive.metastore.model.MStringList
 
toString() - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.FilterBuilder
 
toString() - Method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
toString() - Method in class org.apache.hadoop.hive.metastore.ProtectMode
 
toString() - Method in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
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.ExprNodeEvaluator
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo.FunctionResource
 
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() - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
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.spark.status.SparkStageProgress
 
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.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
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.VectorizationContext
 
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.hooks.LineageInfo.BaseColumnInfo
 
toString() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
 
toString() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
toString() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
toString() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
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.timestamp.NanoTime
 
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.DefaultStorageHandler
 
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.calcite.cost.HiveCost
 
toString() - Method in interface org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModel.JoinAlgorithm
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModel.DefaultJoinAlgorithm
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezBucketJoinAlgorithm
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezCommonJoinAlgorithm
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezMapJoinAlgorithm
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModel.TezSMBJoinAlgorithm
 
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 enum org.apache.hadoop.hive.ql.parse.ReplicationSpec.KEY
 
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.api.Adjacency
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics.Range
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsUpdateWork
 
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.ExprNodeDynamicListDesc
 
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 class org.apache.hadoop.hive.ql.plan.FilterDesc.SampleDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
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.processors.CommandProcessorResponse
 
toString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzSessionContext
 
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 class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
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
 
toString() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
toString() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
toString() - Method in class org.apache.hadoop.hive.serde2.BaseStructObjectInspector.MyField
 
toString() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
toString() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
toString() - Method in class org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe
 
toString() - Method in class org.apache.hadoop.hive.serde2.ColumnSet
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
toString(String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
toString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.Token
Returns the image.
toString() - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.HiveCharWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.HiveVarcharWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveCharObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyHiveVarcharObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
toString() - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
toString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
toString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
toString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
toString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
toString() - Method in class org.apache.hadoop.hive.serde2.typeinfo.CharTypeInfo
 
toString() - Method in class org.apache.hadoop.hive.serde2.typeinfo.DecimalTypeInfo
 
toString() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
toString() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
toString() - Method in class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
 
toString() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
toString() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
toString() - Method in class org.apache.hive.beeline.OutputFile
 
toString() - Method in class org.apache.hive.common.util.BloomFilter
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatAddPartitionDesc
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatCreateDBDesc
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatCreateTableDesc
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatDatabase
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatNotificationEvent
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatPartition
 
toString() - Method in class org.apache.hive.hcatalog.api.HCatTable
 
toString() - Method in exception org.apache.hive.hcatalog.common.HCatException
 
toString() - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
toString() - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
toString() - Method in class org.apache.hive.hcatalog.data.Pair
 
toString() - Method in class org.apache.hive.hcatalog.data.schema.HCatFieldSchema
 
toString() - Method in class org.apache.hive.hcatalog.data.schema.HCatSchema
 
toString() - Method in enum org.apache.hive.hcatalog.messaging.HCatEventMessage.EventType
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAddPartitionMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterPartitionMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONAlterTableMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateDatabaseMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONCreateTableMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropDatabaseMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropPartitionMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONDropTableMessage
 
toString() - Method in class org.apache.hive.hcatalog.messaging.json.JSONInsertMessage
 
toString() - Method in class org.apache.hive.hcatalog.streaming.HiveEndPoint
 
toString() - Method in class org.apache.hive.hcatalog.templeton.ColumnDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.DatabaseDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.ExecBean
 
toString() - Method in class org.apache.hive.hcatalog.templeton.PartitionDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.TableDesc.ClusteredByDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.TableDesc.ClusterSortOrderDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.TableDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.TableLikeDesc
 
toString() - Method in class org.apache.hive.hcatalog.templeton.TablePropertyDesc
 
toString() - Method in enum org.apache.hive.service.auth.SaslQOP
 
toString() - Method in class org.apache.hive.service.cli.Handle
 
toString() - Method in class org.apache.hive.service.cli.HandleIdentifier
 
toString(Throwable) - Static method in exception org.apache.hive.service.cli.HiveSQLException
Converts a Throwable object into a flattened list of texts including its stack trace and the stack traces of the nested causes.
toString() - Method in class org.apache.hive.service.cli.OperationHandle
 
toString() - Method in class org.apache.hive.service.cli.PatternOrIdentifier
 
toString() - Method in class org.apache.hive.service.cli.SessionHandle
 
toString() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
toString() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
toString() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
toString() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
toString() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
toString() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
toString() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
toString() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
toString() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
toString() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
toString() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
toString() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
toString() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
toString() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
toString() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
toString() - Method in class org.apache.hive.service.cli.thrift.TRow
 
toString() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
toString() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
toString() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
toString() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
toString() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
toString() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
toString() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
toString() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
toString() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
toString() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
toString() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
toString() - Method in class org.apache.hive.spark.counter.SparkCounters
 
toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.debug.Utils
Outputs some bytes as hex w/printable characters prints.
toStringWordCharsOnly(String) - Static method in class org.apache.hive.hcatalog.api.repl.ReplicationUtils
Return alphanumeric(and '_') chars only of a string, lowercased
TOTAL_SIZE - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
The name of the statistic Total Size to be published or gathered.
totalFiles - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
totalMonths - Variable in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
totalSeconds - Variable in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
totalSz - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
totaltime - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
toTaskTempPath(Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
toTColumn() - Method in class org.apache.hive.service.cli.Column
 
toTColumnDesc() - Method in class org.apache.hive.service.cli.ColumnDescriptor
 
toTColumnValue(Type, Object) - Static method in class org.apache.hive.service.cli.ColumnValue
 
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.
toTFetchOrientation() - Method in enum org.apache.hive.service.cli.FetchOrientation
 
toTFetchType() - Method in enum org.apache.hive.service.cli.FetchType
 
toTGetInfoType() - Method in enum org.apache.hive.service.cli.GetInfoType
 
toTGetInfoValue() - Method in class org.apache.hive.service.cli.GetInfoValue
 
toTHandleIdentifier() - Method in class org.apache.hive.service.cli.HandleIdentifier
 
toThriftJSONString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toThriftPayload(Object, ObjectInspector, int) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
Convert a Object to a standard Java object in compliance with JDBC 3.0 (see JDBC 3.0 Specification, Table B-3: Mapping from JDBC Types to Java Object Types).
toTime(String, TimeUnit, TimeUnit) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
toTOperationHandle() - Method in class org.apache.hive.service.cli.OperationHandle
 
toTOperationState() - Method in enum org.apache.hive.service.cli.OperationState
 
toTOperationType() - Method in enum org.apache.hive.service.cli.OperationType
 
toTRowSet() - Method in class org.apache.hive.service.cli.ColumnBasedSet
 
toTRowSet() - Method in class org.apache.hive.service.cli.RowBasedSet
 
toTRowSet() - Method in interface org.apache.hive.service.cli.RowSet
 
toTSessionHandle() - Method in class org.apache.hive.service.cli.SessionHandle
 
toTStatus() - Method in exception org.apache.hive.service.cli.HiveSQLException
Converts current object to a TStatus object
toTStatus(Exception) - Static method in exception org.apache.hive.service.cli.HiveSQLException
Converts the specified Exception object into a TStatus object
toTTableSchema() - Method in class org.apache.hive.service.cli.TableSchema
 
toTType() - Method in enum org.apache.hive.service.cli.Type
 
toTTypeDesc() - Method in class org.apache.hive.service.cli.TypeDescriptor
 
toTTypeQualifiers() - Method in class org.apache.hive.service.cli.TypeQualifiers
 
toTypes() - Method in class org.apache.hive.service.cli.TableSchema
 
toWalk - Variable in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
toWriteEntity(String) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
toWriteEntity(Path) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
toZeroIndex(int) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
TPrimitiveTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TPrimitiveTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
TPrimitiveTypeEntry(TTypeId) - Constructor for class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
TPrimitiveTypeEntry(TPrimitiveTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
Performs a deep copy on other.
TPrimitiveTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TProtocolVersion - Enum in org.apache.hive.service.cli.thrift
 
TRACKINGDIR - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
TraitsUtil - Class in org.apache.hadoop.hive.ql.optimizer.calcite
 
TraitsUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.TraitsUtil
 
TransactionBatch - Interface in org.apache.hive.hcatalog.streaming
Represents a set of Transactions returned by Hive.
TransactionBatch.TxnState - Enum in org.apache.hive.hcatalog.streaming
 
TransactionBatchUnAvailable - Exception in org.apache.hive.hcatalog.streaming
 
TransactionBatchUnAvailable(HiveEndPoint, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.TransactionBatchUnAvailable
 
TransactionError - Exception in org.apache.hive.hcatalog.streaming
 
TransactionError(String, Exception) - Constructor for exception org.apache.hive.hcatalog.streaming.TransactionError
 
TransactionError(String) - Constructor for exception org.apache.hive.hcatalog.streaming.TransactionError
 
transform(JavaPairRDD<WritableComparable, Writable>) - Method in class org.apache.hadoop.hive.ql.exec.spark.MapInput
 
transform(JavaPairRDD<BytesWritable, BytesWritable>) - Method in class org.apache.hadoop.hive.ql.exec.spark.MapTran
 
transform(JavaPairRDD<HiveKey, Iterable<BytesWritable>>) - Method in class org.apache.hadoop.hive.ql.exec.spark.ReduceTran
 
transform(JavaPairRDD<HiveKey, BytesWritable>) - Method in class org.apache.hadoop.hive.ql.exec.spark.ShuffleTran
 
transform(JavaPairRDD<KI, VI>) - Method in interface org.apache.hadoop.hive.ql.exec.spark.SparkTran
 
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.calcite.translator.HiveOpConverterPostProc
 
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.ConstantPropagate
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.IdentityProjectRemover
 
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(Collection<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.PredicateTransitivePropagate
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.SyntheticJoinPredicate
 
transformFromUTF8(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
transform Writable data from UTF-8 to charset before serialize.
transformFromUTF8(Writable) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
transformRawInput(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
transformRawInputIterator(PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
transformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.MatchPathResolver
 
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
 
transformTextFromUTF8(Text, Charset) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
transformTextToUTF8(Text, Charset) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
transformToUTF8(Writable) - Method in class org.apache.hadoop.hive.serde2.AbstractEncodingAwareSerDe
transform Writable data from charset to UTF-8 before doDeserialize.
transformToUTF8(Writable) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
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
 
translate() - Method in class org.apache.hadoop.hive.ql.udf.ptf.MatchPath.ResultExpressionParser
 
translateBitSetToProjIndx(ImmutableBitSet) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
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).
transportTokenizer - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The transport stream is tokenized on the row separator.
trashFilesUnderDir(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hive.common.FileUtils
Deletes all files under a directory, sending them to the trash.
traverse(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
traversed - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
tree - Variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
TreeReaderFactory - Class in org.apache.hadoop.hive.ql.io.orc
Factory for creating ORC tree readers.
TreeReaderFactory() - Constructor for class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory
 
TreeReaderFactory.BinaryTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.BooleanTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.BytesColumnVectorUtil - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.BytesColumnVectorUtil() - Constructor for class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.BytesColumnVectorUtil
 
TreeReaderFactory.ByteTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.CharTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.DateTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.DecimalTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.DoubleTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.FloatTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.IntTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.ListTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.LongTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.MapTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.ShortTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.StringDictionaryTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
A reader for string columns that are dictionary encoded in the current stripe.
TreeReaderFactory.StringDirectTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
A reader for string columns that are direct encoded in the current stripe.
TreeReaderFactory.StringTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
A tree reader that will read string columns.
TreeReaderFactory.StructTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.TimestampTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.TreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.UnionTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TreeReaderFactory.VarcharTreeReader - Class in org.apache.hadoop.hive.ql.io.orc
 
TReflectionUtils - Class in org.apache.hadoop.hive.serde2.thrift
TReflectionUtils.
TRenewDelegationTokenReq - Class in org.apache.hive.service.cli.thrift
 
TRenewDelegationTokenReq() - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
TRenewDelegationTokenReq(TSessionHandle, String) - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
TRenewDelegationTokenReq(TRenewDelegationTokenReq) - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
Performs a deep copy on other.
TRenewDelegationTokenReq._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TRenewDelegationTokenResp - Class in org.apache.hive.service.cli.thrift
 
TRenewDelegationTokenResp() - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
TRenewDelegationTokenResp(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
TRenewDelegationTokenResp(TRenewDelegationTokenResp) - Constructor for class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
Performs a deep copy on other.
TRenewDelegationTokenResp._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
trfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
trfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
trimChild(RelNode, RelNode, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveRelFieldTrimmer
 
trimMapNulls(Map<String, String>, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
We have aneed to sanity-check the map before conversion from persisted objects to metadata thrift objects because null values in maps will cause a NPE if we send across thrift.
TrimQuotes(String) - Static method in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
TRow - Class in org.apache.hive.service.cli.thrift
 
TRow() - Constructor for class org.apache.hive.service.cli.thrift.TRow
 
TRow(List<TColumnValue>) - Constructor for class org.apache.hive.service.cli.thrift.TRow
 
TRow(TRow) - Constructor for class org.apache.hive.service.cli.thrift.TRow
Performs a deep copy on other.
TRow._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TRowSet - Class in org.apache.hive.service.cli.thrift
 
TRowSet() - Constructor for class org.apache.hive.service.cli.thrift.TRowSet
 
TRowSet(long, List<TRow>) - Constructor for class org.apache.hive.service.cli.thrift.TRowSet
 
TRowSet(TRowSet) - Constructor for class org.apache.hive.service.cli.thrift.TRowSet
Performs a deep copy on other.
TRowSet._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TRUE - Static variable in class org.apache.hadoop.hive.common.StatsSetupConst
 
trueBytes - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
truncate(byte[], int, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
truncate(BytesColumnVector, int, byte[], int, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
truncateScalar(byte[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
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
 
truncateTableStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TruncStringOutput - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
tryCount - Variable in class org.apache.hadoop.hive.ql.Context
 
tryCreate(String) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.CheckerFactory
If the given pattern is acceptable for its checker class, it creates and returns a checker.
tryStoreKey(HiveKey, boolean) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
tryStoreKey(HiveKey, boolean) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Try store the non-vectorized key.
tryStoreVectorizedKey(HiveKey, boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
tryStoreVectorizedKey(HiveKey, boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Try to put the key from the current vectorized batch into the heap.
ts - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
TServerSocketKeepAlive - Class in org.apache.hadoop.hive.metastore
TServerSocketKeepAlive - like TServerSocket, but will enable keepalive for accepted sockets.
TServerSocketKeepAlive(int) - Constructor for class org.apache.hadoop.hive.metastore.TServerSocketKeepAlive
 
TSessionHandle - Class in org.apache.hive.service.cli.thrift
 
TSessionHandle() - Constructor for class org.apache.hive.service.cli.thrift.TSessionHandle
 
TSessionHandle(THandleIdentifier) - Constructor for class org.apache.hive.service.cli.thrift.TSessionHandle
 
TSessionHandle(TSessionHandle) - Constructor for class org.apache.hive.service.cli.thrift.TSessionHandle
Performs a deep copy on other.
TSessionHandle._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSetIpAddressProcessor<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore
TSetIpAddressProcessor passes the IP address of the Thrift client to the HMSHandler.
TSetIpAddressProcessor(I) - Constructor for class org.apache.hadoop.hive.metastore.TSetIpAddressProcessor
 
TSetIpAddressProcessor<I extends TCLIService.Iface> - Class in org.apache.hive.service.auth
This class is responsible for setting the ipAddress for operations executed via HiveServer2.
TSetIpAddressProcessor(TCLIService.Iface) - Constructor for class org.apache.hive.service.auth.TSetIpAddressProcessor
 
tsk - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
TStatus - Class in org.apache.hive.service.cli.thrift
 
TStatus() - Constructor for class org.apache.hive.service.cli.thrift.TStatus
 
TStatus(TStatusCode) - Constructor for class org.apache.hive.service.cli.thrift.TStatus
 
TStatus(TStatus) - Constructor for class org.apache.hive.service.cli.thrift.TStatus
Performs a deep copy on other.
TStatus._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TStatusCode - Enum in org.apache.hive.service.cli.thrift
 
tsToEventMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
TStringColumn - Class in org.apache.hive.service.cli.thrift
 
TStringColumn() - Constructor for class org.apache.hive.service.cli.thrift.TStringColumn
 
TStringColumn(List<String>, ByteBuffer) - Constructor for class org.apache.hive.service.cli.thrift.TStringColumn
 
TStringColumn(TStringColumn) - Constructor for class org.apache.hive.service.cli.thrift.TStringColumn
Performs a deep copy on other.
TStringColumn._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TStringValue - Class in org.apache.hive.service.cli.thrift
 
TStringValue() - Constructor for class org.apache.hive.service.cli.thrift.TStringValue
 
TStringValue(TStringValue) - Constructor for class org.apache.hive.service.cli.thrift.TStringValue
Performs a deep copy on other.
TStringValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TStructTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TStructTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
TStructTypeEntry(Map<String, Integer>) - Constructor for class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
TStructTypeEntry(TStructTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TStructTypeEntry
Performs a deep copy on other.
TStructTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSubjectAssumingTransport - Class in org.apache.hive.service.auth
This is used on the client side, where the API explicitly opens a transport to the server using the Subject.doAs().
TSubjectAssumingTransport(TTransport) - Constructor for class org.apache.hive.service.auth.TSubjectAssumingTransport
 
TTableSchema - Class in org.apache.hive.service.cli.thrift
 
TTableSchema() - Constructor for class org.apache.hive.service.cli.thrift.TTableSchema
 
TTableSchema(List<TColumnDesc>) - Constructor for class org.apache.hive.service.cli.thrift.TTableSchema
 
TTableSchema(TTableSchema) - Constructor for class org.apache.hive.service.cli.thrift.TTableSchema
Performs a deep copy on other.
TTableSchema._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTypeDesc - Class in org.apache.hive.service.cli.thrift
 
TTypeDesc() - Constructor for class org.apache.hive.service.cli.thrift.TTypeDesc
 
TTypeDesc(List<TTypeEntry>) - Constructor for class org.apache.hive.service.cli.thrift.TTypeDesc
 
TTypeDesc(TTypeDesc) - Constructor for class org.apache.hive.service.cli.thrift.TTypeDesc
Performs a deep copy on other.
TTypeDesc._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TTypeEntry
 
TTypeEntry(TTypeEntry._Fields, Object) - Constructor for class org.apache.hive.service.cli.thrift.TTypeEntry
 
TTypeEntry(TTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TTypeEntry
 
TTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTypeId - Enum in org.apache.hive.service.cli.thrift
 
TTypeQualifiers - Class in org.apache.hive.service.cli.thrift
 
TTypeQualifiers() - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
TTypeQualifiers(Map<String, TTypeQualifierValue>) - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
TTypeQualifiers(TTypeQualifiers) - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifiers
Performs a deep copy on other.
TTypeQualifiers._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTypeQualifierValue - Class in org.apache.hive.service.cli.thrift
 
TTypeQualifierValue() - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
TTypeQualifierValue(TTypeQualifierValue._Fields, Object) - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
TTypeQualifierValue(TTypeQualifierValue) - Constructor for class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
TTypeQualifierValue._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TUGIAssumingTransport - Class in org.apache.hadoop.hive.thrift.client
The Thrift SASL transports call Sasl.createSaslServer and Sasl.createSaslClient inside open().
TUGIAssumingTransport(TTransport, UserGroupInformation) - Constructor for class org.apache.hadoop.hive.thrift.client.TUGIAssumingTransport
 
TUGIBasedProcessor<I extends ThriftHiveMetastore.Iface> - Class in org.apache.hadoop.hive.metastore
TUGIBasedProcessor is used in unsecure mode for thrift metastore client server communication.
TUGIBasedProcessor(I) - Constructor for class org.apache.hadoop.hive.metastore.TUGIBasedProcessor
 
TUGIContainingTransport - Class in org.apache.hadoop.hive.thrift
TUGIContainingTransport associates ugi information with connection (transport).
TUGIContainingTransport(TTransport) - Constructor for class org.apache.hadoop.hive.thrift.TUGIContainingTransport
 
TUGIContainingTransport.Factory - Class in org.apache.hadoop.hive.thrift
Factory to create TUGIContainingTransport.
TUGIContainingTransport.Factory() - Constructor for class org.apache.hadoop.hive.thrift.TUGIContainingTransport.Factory
 
TUnionTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TUnionTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
TUnionTypeEntry(Map<String, Integer>) - Constructor for class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
TUnionTypeEntry(TUnionTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TUnionTypeEntry
Performs a deep copy on other.
TUnionTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsData
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequestData
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.RequestPartsSpec
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumn
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumnValue
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoValue
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifierValue
 
turnaroundtime - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
TUserDefinedTypeEntry - Class in org.apache.hive.service.cli.thrift
 
TUserDefinedTypeEntry() - Constructor for class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
TUserDefinedTypeEntry(String) - Constructor for class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
TUserDefinedTypeEntry(TUserDefinedTypeEntry) - Constructor for class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
Performs a deep copy on other.
TUserDefinedTypeEntry._Fields - Enum in org.apache.hive.service.cli.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TXN_ABORTED - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
TXN_OPEN - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
TxnAbortedException - Exception in org.apache.hadoop.hive.metastore.api
 
TxnAbortedException() - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
TxnAbortedException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
TxnAbortedException(TxnAbortedException) - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
Performs a deep copy on other.
TxnAbortedException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TxnDbUtil - Class in org.apache.hadoop.hive.metastore.txn
Utility methods for creating and destroying txn database/schema.
TxnHandler - Class in org.apache.hadoop.hive.metastore.txn
A handler to answer transaction related calls that come into the metastore server.
TxnHandler(HiveConf) - Constructor for class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
TxnHandler.DatabaseProduct - Enum in org.apache.hadoop.hive.metastore.txn
 
TxnHandler.RetryException - Exception in org.apache.hadoop.hive.metastore.txn
 
TxnHandler.RetryException() - Constructor for exception org.apache.hadoop.hive.metastore.txn.TxnHandler.RetryException
 
TxnInfo - Class in org.apache.hadoop.hive.metastore.api
 
TxnInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.TxnInfo
 
TxnInfo(long, TxnState, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.TxnInfo
 
TxnInfo(TxnInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.TxnInfo
Performs a deep copy on other.
TxnInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TxnManagerFactory - Class in org.apache.hadoop.hive.ql.lockmgr
A factory to get an instance of HiveTxnManager.
TxnOpenException - Exception in org.apache.hadoop.hive.metastore.api
 
TxnOpenException() - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
TxnOpenException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
TxnOpenException(TxnOpenException) - Constructor for exception org.apache.hadoop.hive.metastore.api.TxnOpenException
Performs a deep copy on other.
TxnOpenException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TxnState - Enum in org.apache.hadoop.hive.metastore.api
 
TXT_FILE_EXT - Static variable in class org.apache.hive.common.util.HiveTestUtils
 
type - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Connection
 
Type - Enum in org.apache.hadoop.hive.contrib.util.typedbytes
The possible type codes.
Type - Class in org.apache.hadoop.hive.metastore.api
 
Type() - Constructor for class org.apache.hadoop.hive.metastore.api.Type
 
Type(String) - Constructor for class org.apache.hadoop.hive.metastore.api.Type
 
Type(Type) - Constructor for class org.apache.hadoop.hive.metastore.api.Type
Performs a deep copy on other.
type - Variable in class org.apache.hadoop.hive.metastore.txn.CompactionInfo
 
type - Variable in class org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter
 
type() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
type - Variable in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
type - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.StringHelper
 
type - Variable in class org.apache.hive.hcatalog.templeton.ColumnDesc
 
Type - Enum in org.apache.hive.service.cli
Type.
Type._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TYPE_NAMES - Static variable in class org.apache.hive.service.cli.thrift.TCLIServiceConstants
 
TypeBool() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypeByte() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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.
TypeCheckCtx(RowResolver, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
TypeCheckProcFactory - Class in org.apache.hadoop.hive.ql.parse
The Factory for creating typecheck processors.
TypeCheckProcFactory() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
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.DateTimeExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for date constants.
TypeCheckProcFactory.DateTimeExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DateTimeExprProcessor
 
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.IntervalExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for interval constants.
TypeCheckProcFactory.IntervalExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.IntervalExprProcessor
 
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.calcite.translator
 
TypeConverter() - Constructor for class org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter
 
TypedBytesInput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Provides functionality for reading typed bytes.
TypedBytesInput(DataInput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesInput
Creates a new instance of TypedBytesInput.
TypedBytesOutput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Provides functionality for writing typed bytes.
TypedBytesOutput(DataOutput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Creates a new instance of TypedBytesOutput.
TypedBytesRecordInput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Serializer for records that writes typed bytes.
TypedBytesRecordInput(TypedBytesInput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordInput(DataInput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordOutput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Deserialized for records that reads typed bytes.
TypedBytesRecordOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesRecordOutput(DataOutput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesRecordReader - Class in org.apache.hadoop.hive.contrib.util.typedbytes
TypedBytesRecordReader.
TypedBytesRecordReader() - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordReader
 
TypedBytesRecordWriter - Class in org.apache.hadoop.hive.contrib.util.typedbytes
TypedBytesRecordWriter.
TypedBytesRecordWriter() - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordWriter
 
TypedBytesSerDe - Class in org.apache.hadoop.hive.contrib.serde2
TypedBytesSerDe uses typed bytes to serialize/deserialize.
TypedBytesSerDe() - Constructor for class org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe
 
TypedBytesWritable - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Writable for typed bytes.
TypedBytesWritable() - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Create a TypedBytesWritable.
TypedBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritable
Create a TypedBytesWritable with a given byte array as initial value.
TypedBytesWritableInput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Provides functionality for reading typed bytes as Writable objects.
TypedBytesWritableInput(TypedBytesInput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableInput(DataInput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableOutput - Class in org.apache.hadoop.hive.contrib.util.typedbytes
Provides functionality for writing Writable objects as typed bytes.
TypedBytesWritableOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.
TypedBytesWritableOutput(DataOutput) - Constructor for class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.
Typedef() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypeDefinition() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypeDescriptor - Class in org.apache.hive.service.cli
TypeDescriptor.
TypeDescriptor(Type) - Constructor for class org.apache.hive.service.cli.TypeDescriptor
 
TypeDescriptor(TTypeDesc) - Constructor for class org.apache.hive.service.cli.TypeDescriptor
 
TypeDescriptor(String) - Constructor for class org.apache.hive.service.cli.TypeDescriptor
 
TypeDouble() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypedSerDe - Class in org.apache.hadoop.hive.serde2
TypedSerDe.
TypedSerDe(Type) - Constructor for class org.apache.hadoop.hive.serde2.TypedSerDe
 
Typei16() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
Typei32() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
Typei64() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
typeInfo - Static variable in class org.apache.hadoop.hive.ql.io.RecordIdentifier.StructInfo
 
typeInfo - Variable in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
typeInfo - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
 
TypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
Stores information about a type.
TypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
typeinfo(String) - Method in class org.apache.hive.beeline.Commands
 
TypeInfoFactory - Class in org.apache.hadoop.hive.serde2.typeinfo
TypeInfoFactory can be used to create the TypeInfo object for any types.
TypeInfoToSchema - Class in org.apache.hadoop.hive.serde2.avro
Convert Hive TypeInfo to an Avro Schema
TypeInfoToSchema() - Constructor for class org.apache.hadoop.hive.serde2.avro.TypeInfoToSchema
 
TypeInfoUtils - Class in org.apache.hadoop.hive.serde2.typeinfo
TypeInfoUtils.
TypeInfoUtils.PrimitiveParts - Class in org.apache.hadoop.hive.serde2.typeinfo
 
TypeInfoUtils.PrimitiveParts() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils.PrimitiveParts
 
TypeList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypeMap() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
typeName - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
typeName is the name of the type as in DDL.
typeName - Variable in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
typeName - Variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils.PrimitiveParts
 
typeNames - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
typeParams - Variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils.PrimitiveParts
 
TypeQualifiers - Class in org.apache.hive.service.cli
This class holds type qualifier information for a primitive type, such as char/varchar length or decimal precision/scale.
TypeQualifiers() - Constructor for class org.apache.hive.service.cli.TypeQualifiers
 
TypeRule - Class in org.apache.hadoop.hive.ql.lib
Rule that matches a particular type of node.
TypeRule(Class<?>) - Constructor for class org.apache.hadoop.hive.ql.lib.TypeRule
 
types - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TYPES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
TypeSet() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
typeString() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
TypeString() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
typeToThriftType(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert type to ThriftType.

U

UDAF - Class in org.apache.hadoop.hive.ql.exec
Deprecated.
Either implement GenericUDAFResolver2 or extend AbstractGenericUDAFResolver instead.
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.
UDAFExampleAvg - Class in org.apache.hadoop.hive.contrib.udaf.example
This is a simple UDAF that calculates average.
UDAFExampleAvg.UDAFAvgState - Class in org.apache.hadoop.hive.contrib.udaf.example
The internal state of an aggregation for average.
UDAFExampleAvg.UDAFAvgState() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFAvgState
 
UDAFExampleAvg.UDAFExampleAvgEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
The actual class for doing the aggregation.
UDAFExampleAvg.UDAFExampleAvgEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleAvg.UDAFExampleAvgEvaluator
 
UDAFExampleGroupConcat - Class in org.apache.hadoop.hive.contrib.udaf.example
This is a simple UDAF that concatenates all arguments from different rows into a single string.
UDAFExampleGroupConcat() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat
 
UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
The actual class for doing the aggregation.
UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleGroupConcat.UDAFExampleGroupConcatEvaluator
 
UDAFExampleMax - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax
 
UDAFExampleMax.MaxDoubleEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxDoubleEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxDoubleEvaluator
 
UDAFExampleMax.MaxFloatEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxFloatEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxFloatEvaluator
 
UDAFExampleMax.MaxIntEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxIntEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxIntEvaluator
 
UDAFExampleMax.MaxLongEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxLongEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxLongEvaluator
 
UDAFExampleMax.MaxShortEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxShortEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxShortEvaluator
 
UDAFExampleMax.MaxStringEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMax.MaxStringEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMax.MaxStringEvaluator
 
UDAFExampleMaxMinNUtil - Class in org.apache.hadoop.hive.contrib.udaf.example
The utility class for UDAFMaxN and UDAFMinN.
UDAFExampleMaxMinNUtil.Evaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
The base class of the UDAFEvaluator for UDAFMaxN and UDAFMinN.
UDAFExampleMaxMinNUtil.Evaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.Evaluator
 
UDAFExampleMaxMinNUtil.State - Class in org.apache.hadoop.hive.contrib.udaf.example
This class stores the information during an aggregation.
UDAFExampleMaxMinNUtil.State() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxMinNUtil.State
 
UDAFExampleMaxN - Class in org.apache.hadoop.hive.contrib.udaf.example
Returns the max N double values.
UDAFExampleMaxN() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxN
 
UDAFExampleMaxN.UDAFMaxNEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
The evaluator for getting max N double values.
UDAFExampleMaxN.UDAFMaxNEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMaxN.UDAFMaxNEvaluator
 
UDAFExampleMin - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin
 
UDAFExampleMin.MinDoubleEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinDoubleEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinDoubleEvaluator
 
UDAFExampleMin.MinFloatEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinFloatEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinFloatEvaluator
 
UDAFExampleMin.MinIntEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinIntEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinIntEvaluator
 
UDAFExampleMin.MinLongEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinLongEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinLongEvaluator
 
UDAFExampleMin.MinShortEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinShortEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinShortEvaluator
 
UDAFExampleMin.MinStringEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
 
UDAFExampleMin.MinStringEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMin.MinStringEvaluator
 
UDAFExampleMinN - Class in org.apache.hadoop.hive.contrib.udaf.example
Returns the min N double values.
UDAFExampleMinN() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMinN
 
UDAFExampleMinN.UDAFMinNEvaluator - Class in org.apache.hadoop.hive.contrib.udaf.example
The evaluator for getting min N double values.
UDAFExampleMinN.UDAFMinNEvaluator() - Constructor for class org.apache.hadoop.hive.contrib.udaf.example.UDAFExampleMinN.UDAFMinNEvaluator
 
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 use with Hive.
UDF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor.
UDF(UDFMethodResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor with user-provided UDFMethodResolver.
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
 
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
 
UDFExampleAdd - Class in org.apache.hadoop.hive.contrib.udf.example
UDFExampleAdd.
UDFExampleAdd() - Constructor for class org.apache.hadoop.hive.contrib.udf.example.UDFExampleAdd
 
UDFExampleArraySum - Class in org.apache.hadoop.hive.contrib.udf.example
UDFExampleArraySum.
UDFExampleArraySum() - Constructor for class org.apache.hadoop.hive.contrib.udf.example.UDFExampleArraySum
 
UDFExampleFormat - Class in org.apache.hadoop.hive.contrib.udf.example
UDFExampleFormat.
UDFExampleFormat() - Constructor for class org.apache.hadoop.hive.contrib.udf.example.UDFExampleFormat
 
UDFExampleMapConcat - Class in org.apache.hadoop.hive.contrib.udf.example
UDFExampleMapConcat.
UDFExampleMapConcat() - Constructor for class org.apache.hadoop.hive.contrib.udf.example.UDFExampleMapConcat
 
UDFExampleStructPrint - Class in org.apache.hadoop.hive.contrib.udf.example
UDFExampleStructPrint.
UDFExampleStructPrint() - Constructor for class org.apache.hadoop.hive.contrib.udf.example.UDFExampleStructPrint
 
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
This class can be used for math based UDFs that only have an evaluate method for doubles.
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
 
UDFOPBitShiftLeft - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitLeftShift.
UDFOPBitShiftLeft() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftLeft
 
UDFOPBitShiftRight - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitRightShift.
UDFOPBitShiftRight() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRight
 
UDFOPBitShiftRightUnsigned - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitUnsignedRightShift.
UDFOPBitShiftRightUnsigned() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitShiftRightUnsigned
 
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
 
UDFRowSequence - Class in org.apache.hadoop.hive.contrib.udf
UDFRowSequence.
UDFRowSequence() - Constructor for class org.apache.hadoop.hive.contrib.udf.UDFRowSequence
 
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 annotations are used to describe properties of a UDF.
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
 
ugi - Variable in class org.apache.hadoop.hive.thrift.client.TUGIAssumingTransport
 
UgiFactory - Class in org.apache.hive.hcatalog.templeton
 
UgiFactory() - Constructor for class org.apache.hive.hcatalog.templeton.UgiFactory
 
UNARY_MINUS_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
UNARY_PLUS_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
UNBOUNDED_AMOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
unCheckedGet(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Gets the BytesRefWritable at the specified position without checking.
UNDERSCORE_INT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
unescapeIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Remove the encapsulating "`" pair from the identifier.
unescapePathName(String) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
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
 
unEscapeString(String) - Static method in class org.apache.hive.common.util.HiveStringUtils
Unescape commas in the string using the default escape char
unEscapeString(String, char, char) - Static method in class org.apache.hive.common.util.HiveStringUtils
Unescape charToEscape in the string with the escape char escapeChar
unEscapeString(String, char, char[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
unEscapeString(String) - Static method in class org.apache.hive.hcatalog.templeton.tool.TempletonUtils
replaces all occurrences of "\," with ","; returns s if no modifications needed
unescapeText(Text) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
UnflagArgs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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.
union - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
UNION_REL_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion
 
UNION_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
UNION_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
UNION = 13;
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
 
unionEntry(TUnionTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
unionMStringString(Map<String, String>) - Static method in class org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion
 
UnionObject - Interface in org.apache.hadoop.hive.serde2.objectinspector
The UnionObject.
UnionObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
UnionObjectInspector works on union data that is stored as UnionObject.
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.
UnionProcessor - Class in org.apache.hadoop.hive.ql.parse
FileSinkProcessor is a simple rule to remember seen unions for later processing.
UnionProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.UnionProcessor
 
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
 
UnionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
UnionStructObjectInspector unions several struct data into a single struct.
UnionStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
UnionStructObjectInspector(List<StructObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
UnionStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
MyField.
UnionStructObjectInspector.MyField() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
UnionStructObjectInspector.MyField(int, StructField) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
unionType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
UnionTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
UnionTypeInfo represents the TypeInfo of an union.
UnionTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
For java serialization use only.
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
 
unionWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
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.
uniqueJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
uniqueJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
uniqueJoinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
uniqueJoinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
uniqueJoinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
uniqueJoinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
uniqueSkewedValueList(List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
Convert value to unique skewed value list.
UNIT_TEST_MODE - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
unitFor(String, TimeUnit) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
UnknownDBException - Exception in org.apache.hadoop.hive.metastore.api
 
UnknownDBException() - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
UnknownDBException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
UnknownDBException(UnknownDBException) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Performs a deep copy on other.
UnknownDBException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnknownPartitionException - Exception in org.apache.hadoop.hive.metastore.api
 
UnknownPartitionException() - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
UnknownPartitionException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
UnknownPartitionException(UnknownPartitionException) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
Performs a deep copy on other.
UnknownPartitionException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnknownTableException - Exception in org.apache.hadoop.hive.metastore.api
 
UnknownTableException() - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
UnknownTableException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
UnknownTableException(UnknownTableException) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Performs a deep copy on other.
UnknownTableException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
unknownTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
unknownTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
unlock(UnlockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.unlock_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
unlock(UnlockRequest, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.unlock_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
unlock(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
unlock(UnlockRequest) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
unlock(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
unlock(long) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
unlock(long) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Unlock a set of locks.
unlock(UnlockRequest) - Method in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
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, long) - 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
 
unlockDatabase() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
UnlockDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
UnlockDatabaseDesc.
UnlockDatabaseDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockDatabaseDesc
 
UnlockRequest - Class in org.apache.hadoop.hive.metastore.api
 
UnlockRequest() - Constructor for class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
UnlockRequest(long) - Constructor for class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
UnlockRequest(UnlockRequest) - Constructor for class org.apache.hadoop.hive.metastore.api.UnlockRequest
Performs a deep copy on other.
UnlockRequest._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
unlockStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
unparseTranslator - Variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
UnparseTranslator - Class in org.apache.hadoop.hive.ql.parse
UnparseTranslator is used to "unparse" objects such as views when their definition is stored.
UnparseTranslator(Configuration) - Constructor for class org.apache.hadoop.hive.ql.parse.UnparseTranslator
 
unregister(ServiceStateChangeListener) - Method in class org.apache.hive.service.AbstractService
 
unregister(ServiceStateChangeListener) - Method in class org.apache.hive.service.FilterService
 
unregister(ServiceStateChangeListener) - Method in interface org.apache.hive.service.Service
Unregister a previously instance of the service state change events.
unregisterFunction(String) - Method in class org.apache.hadoop.hive.ql.exec.Registry
 
unregisterOperationLog() - Method in class org.apache.hive.service.cli.operation.Operation
 
unregisterPermanentFunction(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
unregisterTemporaryUDF(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
unscaledValue() - Method in class org.apache.hadoop.hive.common.type.HiveDecimal
 
unsetAborted() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
unsetAcquiredat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
unsetAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
unsetAttributes() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
unsetAvgColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
unsetBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
unsetCascade() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
unsetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
unsetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
unsetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
unsetCatalogName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
unsetChildren() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetClassName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetClient_protocol() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
unsetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
unsetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
unsetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
unsetCol_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
unsetColName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
unsetColNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
unsetColNames() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
unsetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetColStats() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
unsetColStats() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
unsetColType() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
unsetColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetColumnName() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
unsetColumnName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
unsetColumns() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
unsetColumns() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
unsetColVals() - Method in class org.apache.hive.service.cli.thrift.TRow
 
unsetComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
unsetComment() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
unsetComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
unsetCompacts() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
unsetComponent() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
unsetCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
unsetConfiguration() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
unsetConfOverlay() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetData() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
unsetDatabase() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
unsetDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
unsetDaysSinceEpoch() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
unsetDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
unsetDefaultPartitionName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
unsetDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
unsetDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
unsetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
unsetDelegationToken() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
unsetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetDest_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
unsetDest_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
unsetEnvironment_context() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
unsetEnvironmentContext() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetErrorCode() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
unsetErrorCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
unsetErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
unsetErrorMessage() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
unsetEventId() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
unsetEventId() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
unsetEventTime() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetEventType() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
unsetEventType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
unsetExpr() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
unsetExpr() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
unsetFetchType() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
unsetField0() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
unsetField1() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
unsetField2() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
unsetField3() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
unsetFields() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
unsetFilesAdded() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
unsetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
unsetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
unsetFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
unsetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
unsetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
unsetFuncName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
unsetFunctionName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetFunctionName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
unsetFunctionType() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGrantorName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetGrantorPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGrantTime() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
unsetGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetGuid() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
unsetHasMoreRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
unsetHasResultSet() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
unsetHasUnknownPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
unsetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
unsetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
unsetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
unsetHighValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetHostname() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
unsetHostname() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
unsetHostname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetHostname() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
unsetId() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
unsetIds() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
unsetIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetIfExists() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetIfNotExists() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
unsetIgnoreProtection() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
unsetIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetInfoMessages() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
unsetInfoType() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
unsetInfoValue() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
unsetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetIsTblLevel() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
unsetKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
unsetKey() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
unsetKeyTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetLastAnalyzed() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
unsetLastEvent() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
unsetLastheartbeat() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetLevel() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
unsetLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetLocation() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetLockid() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
unsetLockid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
unsetLockid() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
unsetLockid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetLockid() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
unsetLocks() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
unsetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
unsetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
unsetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
unsetLowValue() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
unsetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMax() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
unsetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetMax_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
unsetMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
unsetMaxColLen() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
unsetMaxEvents() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
unsetMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMaxParts() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
unsetMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMaxRows() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
unsetMessage() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetMin() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
unsetModifiedRowCount() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
unsetMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetMy_16bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_32bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_64bit_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_binary() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_bool() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_byte() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_double() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enum() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
unsetMy_enum_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enum_stringlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enum_struct_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enum_structlist_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enumlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_enumset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_string() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
unsetMy_string_enum_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_string_string_map() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_stringlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_stringset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_structlist() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMy_structset() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
unsetMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
unsetMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetNames() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
unsetNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
unsetNameToTypePtr() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
unsetNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
unsetNeedResult() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
unsetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
unsetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
unsetNew_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
unsetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
unsetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
unsetNewFunc() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
unsetNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
unsetNosuch() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
unsetNulls() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
unsetNum_txns() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
unsetNumBuckets() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
unsetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
unsetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
unsetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
unsetNumDVs() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
unsetNumFalses() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
unsetNumNulls() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
unsetNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
unsetNumTrues() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
unsetO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO5() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetO6() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
unsetObjectName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetObjectTypePtr() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
unsetOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
unsetOpen_txns() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
unsetOperationHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
unsetOperationId() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
unsetOperationState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
unsetOperationType() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
unsetOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetOrientation() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
unsetOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetOwner() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
unsetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetOwnerType() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
unsetPartArchiveLevel() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
unsetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPartitionList() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
unsetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
unsetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
unsetPartitionname() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetPartitionnames() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
unsetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
unsetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
unsetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
unsetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
unsetPartitions() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
unsetPartitionSpecs() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
unsetPartitionVals() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
unsetPartName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
unsetPartname() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetPartNames() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
unsetParts() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
unsetParts() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetPartsFound() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
unsetPartStats() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
unsetPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetPassword() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetPosition() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
unsetPrincipalGrants() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
unsetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetPrivilege() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
unsetProperties() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
unsetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
unsetQualifiers() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
unsetQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
unsetQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetRelativePath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetRenewer() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
unsetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
unsetReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
unsetReq() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
unsetReq() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
unsetRequest() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
unsetRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
unsetRequestType() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetResourceType() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
unsetResourceUris() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
unsetResults() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
unsetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetRevokeGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
unsetRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
unsetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
unsetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
unsetRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetRootPath() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
unsetRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
unsetRows() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
unsetRqst() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
unsetRunas() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
unsetRunAs() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetRunAsync() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
unsetScale() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
unsetSchema() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
unsetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
unsetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
unsetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
unsetSchemaName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetSecret() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
unsetSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetSerializationLib() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
unsetServerProtocolVersion() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
unsetSessionHandle() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
unsetSessionId() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
unsetSharedSDPartitionSpec() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
unsetSIntString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
unsetSkewedColNames() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
unsetSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
unsetSkewedColValues() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
unsetSkewedInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetSource_db() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
unsetSource_table_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
unsetSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetSqlState() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
unsetSqlState() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
unsetStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStart() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetStartRowOffset() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
unsetState() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
unsetState() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetState() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetState() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
unsetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetStatement() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
unsetStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
unsetStats_obj() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
unsetStatsData() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
unsetStatsDesc() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
unsetStatsObj() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
unsetStatus() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
unsetStatusCode() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
unsetStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
unsetSuccess() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
unsetSuccessful() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
unsetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
unsetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
unsetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
unsetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
unsetTablename() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
unsetTablename() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
unsetTablename() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
unsetTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetTablename() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetTableName() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
unsetTableName() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
unsetTableStats() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
unsetTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetTableTypes() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
unsetTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
unsetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
unsetTbl_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
unsetTblName() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
unsetTblName() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
unsetTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
unsetTblName() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
unsetTblName() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
unsetTemporary() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetThrow_exception() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
unsetToken_owner() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
unsetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
unsetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
unsetTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
unsetTxn_high_water_mark() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
unsetTxn_ids() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
unsetTxnid() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetTxns() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
unsetType() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
unsetType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetTypeClassName() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
unsetTypeDesc() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
unsetTypeQualifiers() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
unsetTypes() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
unsetUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
unsetUnionField1() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetUnionField2() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetUnionField3() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetUnscaled() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
unsetUri() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
unsetUser() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
unsetUser() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
unsetUser() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
unsetUser() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
unsetUsername() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
unsetUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
unsetValue() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
unsetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetValues() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
unsetValues() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
unsetValueTypePtr() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
unsetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
unsetViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetWorkerid() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
UnsignedInt128 - Class in org.apache.hadoop.hive.common.type
This code was based on code from Microsoft's PolyBase.
UnsignedInt128() - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Creates an instance that represents zero.
UnsignedInt128(UnsignedInt128) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Copy constructor.
UnsignedInt128(int, int, int, int) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Creates an instance that has the given values.
UnsignedInt128(long) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Constructs from the given long value.
UnsignedInt128(String) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Constructs from the given string.
UnsignedInt128(char[], int, int) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Constructs from the given string with given offset and length.
UnsignedInt128(BigInteger) - Constructor for class org.apache.hadoop.hive.common.type.UnsignedInt128
Constructs from the given BigInteger
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveConfigContext
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveConnection
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveDataSource
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveResultSetMetaData
 
unwrap(Class<T>) - Method in class org.apache.hive.jdbc.HiveStatement
 
unwrap(byte[], int, int) - Method in class org.apache.hive.service.auth.PlainSaslServer
 
unwrapAuthenticationToken(JobConf, AuthenticationToken) - Method in class org.apache.hadoop.hive.accumulo.HiveAccumuloHelper
Wrapper around ConfiguratorBase.unwrapAuthenticationToken which only exists in 1.7.0 and new.
UnwrapRowContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
Unwraps values from current key with valueIndex in mapjoin desc
UnwrapRowContainer(byte, int[], boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
update(Decimal128) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Copy the value of given object.
update(Decimal128, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Copy the value of given object and assigns a custom scale.
update(long) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Update the value of this object with the given long.
update(long, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Update the value of this object with the given long with the given scal.
update(double, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Update the value of this object with the given double.
update(IntBuffer, int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from ByteBuffer, using the required number of ints for the given precision.
update(int[], int, int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from the given array, using the required number of ints for the given precision.
update(BigDecimal) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object with the given BigDecimal.
update(BigInteger, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object with the given BigInteger and scale.
update(String, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object with the given string.
update(char[], int, int, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object from the given string with given offset and length.
update(long) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the given long value.
update(SignedInt128) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the value of the given object.
update(String) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object with the given string.
update(char[], int, int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object from the given string with given offset and length.
update(BigInteger) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object from the given BigInteger.
update(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Copy from the given object.
update(long) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object with the given long value.
update(int, int, int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object with the given values.
update(IntBuffer, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from ByteBuffer, using the required number of ints for the given precision.
update(int[], int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from the given array, using the required number of ints for the given precision.
update(String) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object with the given string.
update(char[], int, int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object from the given string with given offset and length.
update(long, Object) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
update(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(Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg
 
update(Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
update(Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
update(Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
update(Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
update(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Update returnObjectInspector and valueInspectorsAreTheSame based on the ObjectInspector seen.
update128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from ByteBuffer, receiving 128+32 bits data (full ranges).
update128(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from the given integers, receiving 128+32 bits of data (full range).
update128(int, int, int, int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the given integers, receiving 128 bits data (full ranges).
update128(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from the given array, receiving 128 bits data (full ranges).
update128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from ByteBuffer, receiving 128 bits data (full ranges).
update128(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from ByteBuffer, receiving 128 bits data (full ranges).
update128(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from the given array, receiving 128 bits data (full ranges).
update32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from ByteBuffer, receiving only 32+32 bits data.
update32(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from the given integers, receiving only 32+32 bits data.
update32(int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the given integers, receiving only 32 bits data.
update32(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from the given array, receiving only 32 bits data.
update32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 32 bits data.
update32(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 32 bits data.
update32(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from the given array, receiving only 32 bits data.
update64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from ByteBuffer, receiving only 64+32 bits data.
update64(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from the given integers, receiving only 64+32 bits data.
update64(int, int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the given integers, receiving only 64 bits data.
update64(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from the given array, receiving only 64 bits data.
update64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 64 bits data.
update64(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 64 bits data.
update64(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from the given array, receiving only 64 bits data.
update96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from ByteBuffer, receiving only 96+32 bits data.
update96(int[], int) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Updates the value of this object by reading from the given integers, receiving only 96+32 bits data.
update96(int, int, int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Update this object with the given integers, receiving only 96 bits data.
update96(int[], int) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from the given array, receiving only 96 bits data.
update96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 96 bits data.
update96(IntBuffer) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from ByteBuffer, receiving only 96 bits data.
update96(int[], int) - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Updates the value of this object by reading from the given array, receiving only 96 bits data.
update_partition_column_statistics(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
update_partition_column_statistics(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
update_partition_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
update_partition_column_statistics(ColumnStatistics) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
update_partition_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
update_table_column_statistics(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
update_table_column_statistics(ColumnStatistics, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
update_table_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
update_table_column_statistics(ColumnStatistics) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
update_table_column_statistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
updateAggregations(GenericUDAFEvaluator.AggregationBuffer[], Object, ObjectInspector, boolean, boolean, Object[][]) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
updateArray(int, Array) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateArray(String, Array) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, Blob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, Blob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, InputStream) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, InputStream, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBoolean(int, boolean) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBoolean(String, boolean) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
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.
updateByte(int, byte) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateByte(String, byte) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBytes(int, byte[]) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateBytes(String, byte[]) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Clob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Clob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateColumnAccessInfo - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Columns accessed by updates
updateColumnStatsState(Statistics.State) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
updateDate(int, Date) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateDate(String, Date) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
UpdateDeleteSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
A subclass of the SemanticAnalyzer that just handles update and delete statements.
UpdateDeleteSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.UpdateDeleteSemanticAnalyzer
 
updateDouble(int, double) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateDouble(String, double) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateFixedPoint(long, short) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Update the value to a decimal value with the decimal point equal to val but with the decimal point inserted scale digits from the right.
updateFloat(int, float) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateFloat(String, float) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateForUnionAll(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Update returnObjectInspector and valueInspectorsAreTheSame based on the ObjectInspector seen for UnionAll.
updateFSRootLocation(URI, URI, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.tools.HiveMetaTool
 
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
 
updateInt(int, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateInt(String, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateIOContext() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
UpdateLineColumn(char) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
updateLong(int, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateLong(String, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateMasterKey(Integer, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
updateMasterKey(Integer, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
updateMasterKey(int, String) - Method in class org.apache.hadoop.hive.thrift.DBTokenStore
 
updateMasterKey(int, String) - Method in interface org.apache.hadoop.hive.thrift.DelegationTokenStore
Update master key (for expiration and setting store assigned sequence within key)
updateMasterKey(int, String) - Method in class org.apache.hadoop.hive.thrift.MemoryTokenStore
 
updateMasterKey(int, String) - Method in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
updateMax(Object, DateObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg
 
updateMax(Object, HiveDecimalObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
updateMax(Object, DoubleObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
updateMax(Object, LongObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
updateMax(Object, OI) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
updateMDatabaseURI(URI, URI, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following APIs - updateMDatabaseURI is used by HiveMetaTool.
updateMin(Object, DateObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDateStatsEvaluator.DateStatsAgg
 
updateMin(Object, HiveDecimalObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
updateMin(Object, DoubleObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
updateMin(Object, LongObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
updateMin(Object, OI) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.NumericStatsAgg
 
updateMStorageDescriptorTblPropURI(URI, URI, String, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Deprecated.
updateMStorageDescriptorTblURI(URI, URI, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following APIs - updateMStorageDescriptorTblURI is used by HiveMetaTool.
updateNCharacterStream(int, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(String, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, NClob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, NClob) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, Reader) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, Reader, long) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNString(int, String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNString(String, String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNull(int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateNull(String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateObject(int, Object) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateObject(String, Object) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateObject(int, Object, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateObject(String, Object, int) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updatePartitionColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Write partition level column statistics to persistent store
updatePartitionColumnStatistics(ColumnStatistics) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Write partition level column statistics to persistent store
updatePartitionColumnStatistics(ColumnStatistics, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
updatePartitionColumnStatistics(ColumnStatistics, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Persists the given column statistics object to the metastore
updatePartitionColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
updatePartitionStatsFast(Partition, Warehouse) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
updatePartitionStatsFast(Partition, Warehouse, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
updatePartitionStatsFast(Partition, Warehouse, boolean, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Updates the numFiles and totalSize parameters for the passed Partition by querying the warehouse if the passed Partition does not already have values for these parameters.
updatePartitionStatsFast(PartitionSpecProxy.PartitionIterator, Warehouse, boolean, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Updates the numFiles and totalSize parameters for the passed Partition by querying the warehouse if the passed Partition does not already have values for these parameters.
updateProgress() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
Report status to JT so that JT won't kill this task if closing takes too long due to too many files to close and the NN is overloaded.
updateRef(int, Ref) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateRef(String, Ref) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateRow() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateRowId(int, RowId) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateRowId(String, RowId) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updatesAreDetected(int) - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
updateSerdeURI(URI, URI, String, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following APIs - updateSerdeURI is used by HiveMetaTool.
updateShort(int, short) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateShort(String, short) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateSkewJoinJobCounter(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
updateSQLXML(int, SQLXML) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateSQLXML(String, SQLXML) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateStateByte(Byte) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.KvSource
Provide updated value for state byte for a key.
updateStateByte(Byte) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
updateStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
updateString(int, String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateString(String, String) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateTableColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Write table level column statistics to persistent store
updateTableColumnStatistics(ColumnStatistics) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Write table level column statistics to persistent store
updateTableColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
updateTableColumnStatistics(ColumnStatistics) - Method in interface org.apache.hadoop.hive.metastore.RawStore
Persists the given column statistics object to the metastore
updateTableColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
updateTableColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient
Write table level column statistics to persistent store
updateTableSchema(String, String, List<HCatFieldSchema>) - Method in class org.apache.hive.hcatalog.api.HCatClient
Updates the Table's column schema to the specified definition.
updateTableSchema(String, String, HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatClient
Updates the Table's whole schema (including column schema, I/O Formats, SerDe definitions, etc.)
updateTableSchema(String, String, List<HCatFieldSchema>) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
updateTableSchema(String, String, HCatTable) - Method in class org.apache.hive.hcatalog.api.HCatClientHMSImpl
 
updateTblPropURI(URI, URI, String, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
The following APIs - updateMStorageDescriptorTblPropURI is used by HiveMetaTool.
updateTime(int, Time) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateTime(String, Time) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateTimestamp(int, Timestamp) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateTimestamp(String, Timestamp) - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
updateUnpartitionedTableStatsFast(Database, Table, Warehouse, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
updateUnpartitionedTableStatsFast(Database, Table, Warehouse, boolean, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
updateUnpartitionedTableStatsFast(Table, FileStatus[], boolean, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Updates the numFiles and totalSize parameters for the passed unpartitioned Table by querying the warehouse if the passed Table does not already have values for these parameters.
updateVarianceDestructive(Decimal128, Decimal128, Decimal128, long) - Method in class org.apache.hadoop.hive.common.type.Decimal128
For UDAF variance we use the algorithm described by Chan, Golub, and LeVeque in "Algorithms for computing the sample variance: analysis and recommendations" The American Statistician, 37 (1983) pp.
updating() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
updating() - Method in class org.apache.hadoop.hive.ql.parse.UpdateDeleteSemanticAnalyzer
 
uploadToHDFS(URI, HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.spark.SparkUtilities
Uploads a local file to HDFS
uriToString(URI[]) - Static method in class org.apache.hive.common.util.HiveStringUtils
 
URL_PREFIX - Static variable in class org.apache.hive.jdbc.Utils
The required prefix for the connection URL.
usage - Variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
usage() - Method in class org.apache.hive.hcatalog.templeton.Main
 
USE_MOCK_INSTANCE - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
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.
useMinMax() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
useMinMax() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinLongHashTable
 
useMinMax() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
useMinMax() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMap
 
useMinMax() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMultiSet
 
useMinMax() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashSet
 
useMockInstance - Variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
useMockInstance() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
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.
useOverflowRepeatedThreshold - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
user - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
USER_DEFAULT_PRECISION - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
Default precision/scale when user doesn't specify in the column metadata, such as decimal and decimal(8).
USER_DEFAULT_SCALE - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
USER_KEYTAB - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
USER_NAME - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
USER_PASS - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
useragent - Variable in class org.apache.hadoop.hive.contrib.serde2.s3.S3LogStruct
 
userargs - Variable in class org.apache.hive.hcatalog.templeton.QueueStatusBean
 
userDefinedTypeEntry(TUserDefinedTypeEntry) - Static method in class org.apache.hive.service.cli.thrift.TTypeEntry
 
userMetadata - Variable in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
userName - Variable in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
useSasl() - Method in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
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
 
usesLocalFilePerTable() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
usesLocalFiles() - Method in class org.apache.hive.jdbc.HiveDatabaseMetaData
 
useSorted() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
useSQL11ReservedKeywordsForIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
useSQL11ReservedKeywordsForIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
useSQL11ReservedKeywordsForIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
useSQL11ReservedKeywordsForIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
usesScript() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
useUniformHash - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
UTF_8 - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloHiveConstants
 
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.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.accumulo
Accumulo doesn't have a TableMapReduceUtil.addDependencyJars method like HBase which is very helpful
Utils() - Constructor for class org.apache.hadoop.hive.accumulo.Utils
 
Utils - Class in org.apache.hadoop.hive.ql.debug
Debug utility methods for Hive.
Utils() - Constructor for class org.apache.hadoop.hive.ql.debug.Utils
 
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
 
Utils - Class in org.apache.hadoop.hive.shims
 
Utils() - Constructor for class org.apache.hadoop.hive.shims.Utils
 
Utils - Class in org.apache.hive.jdbc
 
Utils() - Constructor for class org.apache.hive.jdbc.Utils
 
Utils.JdbcConnectionParams - Class in org.apache.hive.jdbc
 
Utils.JdbcConnectionParams() - Constructor for class org.apache.hive.jdbc.Utils.JdbcConnectionParams
 

V

VALID_TXNS_KEY - Static variable in interface org.apache.hadoop.hive.common.ValidTxnList
Key used to store valid txn list in a Configuration object.
validate(String) - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
validate(String) - Method in class org.apache.hadoop.hive.conf.Validator.PatternSet
 
validate(String) - Method in class org.apache.hadoop.hive.conf.Validator.RangeValidator
 
validate(String) - Method in class org.apache.hadoop.hive.conf.Validator.RatioValidator
 
validate(String) - Method in class org.apache.hadoop.hive.conf.Validator.StringSet
 
validate(String) - Method in class org.apache.hadoop.hive.conf.Validator.TimeValidator
 
validate(String) - Method in interface org.apache.hadoop.hive.conf.Validator
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Date
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Function
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
validate(ExprNodeFieldDesc) - Method in interface org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer.FieldValidator
 
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() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
validate(HiveConf) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
validate() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
validate() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
validate() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
validate() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
validate() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
validate() - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
validate() - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
validate() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
validate() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
validate() - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
validate() - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
validate() - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
validate() - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
validate() - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
validate() - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
validate() - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
validate() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
validate() - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
validate() - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
validate() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
validate() - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
validate() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
validate() - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
validate() - Method in class org.apache.hive.service.cli.thrift.TRow
 
validate() - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
validate() - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
validate() - Method in class org.apache.hive.service.cli.thrift.TStatus
 
validate() - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
validate() - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
validate() - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
validate() - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
validate() - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
validate() - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
validate() - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
validate() - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
validateAndMakeEffective() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
validateASTForUnsupportedTokens(ASTNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil
 
validateCharParameter(int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharUtils
 
validateColumnName(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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
 
validateColumns(List<FieldSchema>, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
 
validateColumnType(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
validate column type if it is predefined, yes.
validateComparable(ObjectInspector, String) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
validateDefaultFetchOrientation(FetchOrientation) - Method in class org.apache.hive.service.cli.operation.Operation
Verify if the given fetch orientation is part of the default orientation types.
validateEventType(HCatNotificationEvent, String) - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
validateExecuteBitPresentIfReadOrWrite(FsAction) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Ensure that read or write permissions are not granted without also granting execute permissions.
validateFetchOrientation(FetchOrientation, EnumSet<FetchOrientation>) - Method in class org.apache.hive.service.cli.operation.Operation
Verify if the given fetch orientation is part of the supported orientation types.
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(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileInputFormat
 
validateJoinFilters(List<RexNode>, List<RexNode>, Join, JoinRelType) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule
 
validateMorePermissive(FsAction, FsAction) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Test if the first FsAction is more permissive than the second.
validateName(String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
validateName Checks the name conforms to our standars which are: "[a-zA-z_0-9]+".
validateNoLeadLagInValueBoundarySpec(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
validateParameter(int, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils
 
validatePartColumnNames(Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
validatePartColumnType(Table, Map<String, String>, ASTNode, HiveConf) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
validatePartitionNameCharacters(List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
validatePartitionNameCharacters(List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
validatePartitionNameCharacters(List<String>, Pattern) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
validatePartitionNameCharacters(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
validatePartitionSchema(Table, HCatSchema) - Static method in class org.apache.hive.hcatalog.common.HCatUtil
Validate partition schema, checks if the column types match between the partition and the existing table schema.
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
validateProgram(String) - Method in class org.apache.hive.hcatalog.templeton.ExecServiceImpl
Given a program name, lookup the fully qualified path.
validateRowId(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Make sure the row ID fits into the row ID column in the table.
validateSkewedColNames(List<String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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.
validateSkewedColNamesSubsetCol(List<String>, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
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
 
validateTblColumns(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
validateTransition(OperationState, OperationState) - Static method in enum org.apache.hive.service.cli.OperationState
 
validateTransition(OperationState) - Method in enum org.apache.hive.service.cli.OperationState
 
validateUDF(ASTNode, boolean, TypeCheckCtx, FunctionInfo, List<ExprNodeDesc>, GenericUDF) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor
 
validateUDF(ASTNode, boolean, TypeCheckCtx, FunctionInfo, List<ExprNodeDesc>, GenericUDF) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
validateVarcharParameter(int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.BaseCharUtils
 
ValidationUtility - Class in org.apache.hadoop.hive.ql.plan
Common utilities for validation.
Validator - Interface in org.apache.hadoop.hive.conf
validate value for a ConfVar, return non-null string for fail message
Validator.PatternSet - Class in org.apache.hadoop.hive.conf
 
Validator.PatternSet(String...) - Constructor for class org.apache.hadoop.hive.conf.Validator.PatternSet
 
Validator.RangeValidator - Class in org.apache.hadoop.hive.conf
 
Validator.RangeValidator(Object, Object) - Constructor for class org.apache.hadoop.hive.conf.Validator.RangeValidator
 
Validator.RatioValidator - Class in org.apache.hadoop.hive.conf
 
Validator.RatioValidator() - Constructor for class org.apache.hadoop.hive.conf.Validator.RatioValidator
 
Validator.StringSet - Class in org.apache.hadoop.hive.conf
 
Validator.StringSet(String...) - Constructor for class org.apache.hadoop.hive.conf.Validator.StringSet
 
Validator.StringSet(boolean, String...) - Constructor for class org.apache.hadoop.hive.conf.Validator.StringSet
 
Validator.TimeValidator - Class in org.apache.hadoop.hive.conf
 
Validator.TimeValidator(TimeUnit) - Constructor for class org.apache.hadoop.hive.conf.Validator.TimeValidator
 
Validator.TimeValidator(TimeUnit, Long, boolean, Long, boolean) - Constructor for class org.apache.hadoop.hive.conf.Validator.TimeValidator
 
Validator.TYPE - Enum in org.apache.hadoop.hive.conf
 
validatorDescription() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
ValidCompactorTxnList - Class in org.apache.hadoop.hive.metastore.txn
And implmentation of ValidTxnList for use by the compactor.
ValidCompactorTxnList() - Constructor for class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
ValidCompactorTxnList(long[], long, long) - Constructor for class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
ValidCompactorTxnList(String) - Constructor for class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
ValidReadTxnList - Class in org.apache.hadoop.hive.common
An implmentation of ValidTxnList for use by readers.
ValidReadTxnList() - Constructor for class org.apache.hadoop.hive.common.ValidReadTxnList
 
ValidReadTxnList(long[], long) - Constructor for class org.apache.hadoop.hive.common.ValidReadTxnList
 
ValidReadTxnList(String) - Constructor for class org.apache.hadoop.hive.common.ValidReadTxnList
 
ValidTxnList - Interface in org.apache.hadoop.hive.common
Models the list of transactions that should be included in a snapshot.
ValidTxnList.RangeResponse - Enum in org.apache.hadoop.hive.common
The response to a range query.
valToPaths - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
value - Variable in class org.apache.hadoop.hive.common.type.HiveBaseChar
 
value - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
Constant expression side of the operator.
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColGreaterStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColLessStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupColNotEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarGreaterStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarLessStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.FilterStringGroupScalarNotEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColGreaterStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColLessStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupColNotEqualStringGroupScalarBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarGreaterStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarLessStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.StringGroupScalarNotEqualStringGroupColumnBase
 
value - Variable in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
value - Variable in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
value - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe.BooleanRef
 
value - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VInt
 
value - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
value - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveCharObjectInspector
 
value - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveVarcharObjectInspector
 
value - Variable in enum org.apache.hive.common.HiveCompat.CompatLevel
 
value - Variable in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
 
value - Variable in class org.apache.hive.hcatalog.templeton.TablePropertyDesc
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
ValueBoundaryDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
ValueBoundaryDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
valueBuffer - Variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
valueEncoding - Variable in class org.apache.hadoop.hive.accumulo.columns.HiveAccumuloMapColumnMapping
 
valueEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
The evaluators for the value columns.
valueInspector - Variable in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
valueObjectInspector - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ant.GenVectorTestCode.TestSuiteClassName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.common.StatsSetupConst.StatDB
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.apache.hadoop.hive.common.type.HiveIntervalDayTime
 
valueOf(String) - Static method in class org.apache.hadoop.hive.common.type.HiveIntervalYearMonth
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.common.ValidTxnList.RangeResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.conf.Validator.TYPE
Returns the enum constant of this type with the specified name.
valueOf(Object, Object) - Static method in enum org.apache.hadoop.hive.conf.Validator.TYPE
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.contrib.util.typedbytes.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.hwi.HWISessionItem.WebSessionItemStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AbortTxnRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddDynamicPartitions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AddPartitionsResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AggrStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CheckLockRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatistics._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CommitTxnRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Date._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DateColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Decimal._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsExpr._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.DropPartitionsResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.EnvironmentContext._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.EventRequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventRequestData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FireEventResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Function._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FunctionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.GrantRevokeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InsertEventRequestData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidInputException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidPartitionException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockComponent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.LongColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchLockException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchTxnException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEvent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NotificationEventResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.OpenTxnsResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsByExprResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpec._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionsStatsResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PartitionWithoutSD._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.RequestPartsSpec._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ResourceUri._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.RolePrincipalGrant._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SkewedInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StringColumnStatsData._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TableStatsResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnAbortedException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnOpenException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.TxnState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownPartitionException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnlockRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.events.PreEventContext.PreEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.IExtrapolatePartStatus.AggrType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.IExtrapolatePartStatus.ColStatType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.LogicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.TableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.txn.TxnHandler.DatabaseProduct
Returns the enum constant of this type with the specified name.
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.FileSinkOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionInfo.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.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.JoinUtil.JoinResult
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.ReduceSinkOperator.Counter
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.spark.status.SparkJobState
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.ColumnVector.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.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.AcidUtils.Operation
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.CompressionCodec.Modifier
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.CompressionStrategy
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.EncodingStrategy
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.orc.OrcFile.WriterVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding.Kind
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream.Kind
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
 
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.RecordIdentifier.Field
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.calcite.CalciteSemanticException.UnsupportedFeature
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin.MapJoinStreamingRelation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverter.HIVEAGGOPMODE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx.ConstantPropagateOption
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.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.QBParseInfo.ClauseType
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.ReplicationSpec.KEY
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.ReplicationSpec.SCOPE
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.api.Adjacency._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
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.Explain.Level
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.ReduceSinkDesc.ReducerTraits
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.plan.TezWork.VertexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc.HashTableImplementationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc.HashTableKeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc.HashTableKind
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.HiveAuthzSessionContext.CLIENT_TYPE
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.HivePrivilegeObject.HivePrivObjectActionType
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.Operation2Privilege.IOType
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.OperationLog.LoggingLevel
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.udf.generic.GenericUDFNextDay.DayOfWeek
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.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils.AvroTableProperties
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness.RequirednessTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory.ObjectInspectorOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils.ObjectInspectorCopyOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveGrouping
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector.PrimitiveCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MegaStruct._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MiniStruct._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.MyEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.PropValueUnion._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.SetIntString._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.JobTrackerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.clean_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.shims.HadoopShims.DirectCompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.shims.HadoopShims.HCatHadoopShims.PropertyName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.shims.HadoopShims.JobTrackerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.shims.HadoopShims.StoragePolicyValue
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server.ServerMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.common.HiveCompat.CompatLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
Returns the enum constant of this type with the specified name.
valueOf(char) - Static method in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
 
valueOf(String) - Static method in enum org.apache.hive.hcatalog.api.HCatClient.DropDBMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.api.HCatNotificationEvent.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.api.HCatTable.TableAttribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.api.HCatTable.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.common.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.common.HCatContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.messaging.HCatEventMessage.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.streaming.TransactionBatch.TxnState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.templeton.LauncherDelegator.JobType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.templeton.TableDesc.SortDirectionDesc
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.hcatalog.templeton.tool.TempletonStorage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.auth.AuthenticationProviderFactory.AuthMethods
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.auth.HiveAuthFactory.AuthTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.auth.SaslQOP
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.FetchOrientation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.FetchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.GetInfoType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.operation.ClassicTableTypeMapping.ClassicTableTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.operation.TableTypeMappingFactory.TableTypeMappings
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.OperationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TFetchOrientation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TOperationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TRow._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TStatusCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.cli.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.service.Service.STATE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.spark.client.JobHandle.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hive.spark.client.metrics.DataReadMethod
Returns the enum constant of this type with the specified name.
valuePresent - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.TreeReader
 
valueReader - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.MapTreeReader
 
valueRowConstructor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
valueRowConstructor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
values() - Static method in enum org.apache.hadoop.hive.accumulo.columns.ColumnEncoding
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.ant.GenVectorTestCode.TestSuiteClassName
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.common.StatsSetupConst.StatDB
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.common.ValidTxnList.RangeResponse
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.conf.HiveConf.ConfVars
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.conf.Validator.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.contrib.util.typedbytes.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.hwi.HWISessionItem.WebSessionItemStatus
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.metastore.api.AbortTxnRequest._Fields
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.metastore.api.AddDynamicPartitions._Fields
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.metastore.api.AddPartitionsRequest._Fields
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.metastore.api.AddPartitionsResult._Fields
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.metastore.api.AggrStats._Fields
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.metastore.api.AlreadyExistsException._Fields
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.metastore.api.BinaryColumnStatsData._Fields
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.metastore.api.BooleanColumnStatsData._Fields
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.metastore.api.CheckLockRequest._Fields
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.metastore.api.ColumnStatistics._Fields
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.metastore.api.ColumnStatisticsData._Fields
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.metastore.api.ColumnStatisticsDesc._Fields
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.metastore.api.ColumnStatisticsObj._Fields
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.metastore.api.CommitTxnRequest._Fields
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.metastore.api.CompactionRequest._Fields
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.metastore.api.CompactionType
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.metastore.api.ConfigValSecurityException._Fields
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.metastore.api.CurrentNotificationEventId._Fields
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.metastore.api.Database._Fields
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.metastore.api.Date._Fields
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.metastore.api.DateColumnStatsData._Fields
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.metastore.api.Decimal._Fields
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.metastore.api.DecimalColumnStatsData._Fields
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.metastore.api.DoubleColumnStatsData._Fields
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.metastore.api.DropPartitionsExpr._Fields
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.metastore.api.DropPartitionsRequest._Fields
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.metastore.api.DropPartitionsResult._Fields
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.metastore.api.EnvironmentContext._Fields
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.metastore.api.EventRequestType
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.metastore.api.FieldSchema._Fields
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.metastore.api.FireEventRequest._Fields
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.metastore.api.FireEventRequestData._Fields
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.metastore.api.FireEventResponse._Fields
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.metastore.api.Function._Fields
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.metastore.api.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.metastore.api.GetOpenTxnsInfoResponse._Fields
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.metastore.api.GetOpenTxnsResponse._Fields
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.metastore.api.GetPrincipalsInRoleRequest._Fields
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.metastore.api.GetPrincipalsInRoleResponse._Fields
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.metastore.api.GetRoleGrantsForPrincipalRequest._Fields
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.metastore.api.GetRoleGrantsForPrincipalResponse._Fields
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.metastore.api.GrantRevokePrivilegeRequest._Fields
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.metastore.api.GrantRevokePrivilegeResponse._Fields
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.metastore.api.GrantRevokeRoleRequest._Fields
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.metastore.api.GrantRevokeRoleResponse._Fields
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.metastore.api.GrantRevokeType
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.metastore.api.HeartbeatRequest._Fields
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.metastore.api.HeartbeatTxnRangeRequest._Fields
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.metastore.api.HeartbeatTxnRangeResponse._Fields
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.metastore.api.HiveObjectPrivilege._Fields
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.metastore.api.HiveObjectRef._Fields
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.metastore.api.HiveObjectType
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.metastore.api.Index._Fields
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.metastore.api.IndexAlreadyExistsException._Fields
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.metastore.api.InsertEventRequestData._Fields
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.metastore.api.InvalidInputException._Fields
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.metastore.api.InvalidObjectException._Fields
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.metastore.api.InvalidOperationException._Fields
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.metastore.api.InvalidPartitionException._Fields
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.metastore.api.LockComponent._Fields
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.metastore.api.LockLevel
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.metastore.api.LockRequest._Fields
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.metastore.api.LockResponse._Fields
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.metastore.api.LockState
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.metastore.api.LockType
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.metastore.api.LongColumnStatsData._Fields
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.metastore.api.MetaException._Fields
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.metastore.api.NoSuchLockException._Fields
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.metastore.api.NoSuchObjectException._Fields
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.metastore.api.NoSuchTxnException._Fields
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.metastore.api.NotificationEvent._Fields
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.metastore.api.NotificationEventRequest._Fields
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.metastore.api.NotificationEventResponse._Fields
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.metastore.api.OpenTxnRequest._Fields
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.metastore.api.OpenTxnsResponse._Fields
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.metastore.api.Order._Fields
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.metastore.api.Partition._Fields
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.metastore.api.PartitionEventType
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.metastore.api.PartitionListComposingSpec._Fields
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.metastore.api.PartitionsByExprRequest._Fields
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.metastore.api.PartitionsByExprResult._Fields
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.metastore.api.PartitionSpec._Fields
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.metastore.api.PartitionSpecWithSharedSD._Fields
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.metastore.api.PartitionsStatsRequest._Fields
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.metastore.api.PartitionsStatsResult._Fields
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.metastore.api.PartitionWithoutSD._Fields
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.metastore.api.PrincipalPrivilegeSet._Fields
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.metastore.api.PrincipalType
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.metastore.api.PrivilegeBag._Fields
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.metastore.api.PrivilegeGrantInfo._Fields
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.metastore.api.RequestPartsSpec._Fields
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.metastore.api.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.metastore.api.ResourceUri._Fields
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.metastore.api.Role._Fields
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.metastore.api.RolePrincipalGrant._Fields
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.metastore.api.Schema._Fields
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.metastore.api.SerDeInfo._Fields
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.metastore.api.SetPartitionsStatsRequest._Fields
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.metastore.api.ShowCompactRequest._Fields
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.metastore.api.ShowCompactResponse._Fields
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.metastore.api.ShowCompactResponseElement._Fields
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.metastore.api.ShowLocksRequest._Fields
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.metastore.api.ShowLocksResponse._Fields
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.metastore.api.ShowLocksResponseElement._Fields
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.metastore.api.SkewedInfo._Fields
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.metastore.api.StorageDescriptor._Fields
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.metastore.api.StringColumnStatsData._Fields
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.metastore.api.Table._Fields
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.metastore.api.TableStatsRequest._Fields
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.metastore.api.TableStatsResult._Fields
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.metastore.api.ThriftHiveMetastore.abort_txn_args._Fields
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.metastore.api.ThriftHiveMetastore.abort_txn_result._Fields
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.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args._Fields
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.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result._Fields
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.metastore.api.ThriftHiveMetastore.add_index_args._Fields
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.metastore.api.ThriftHiveMetastore.add_index_result._Fields
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.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_args._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_req_args._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_req_result._Fields
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.metastore.api.ThriftHiveMetastore.add_partitions_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_function_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_function_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_partitions_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_partitions_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
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.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
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.metastore.api.ThriftHiveMetastore.check_lock_args._Fields
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.metastore.api.ThriftHiveMetastore.check_lock_result._Fields
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.metastore.api.ThriftHiveMetastore.commit_txn_args._Fields
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.metastore.api.ThriftHiveMetastore.commit_txn_result._Fields
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.metastore.api.ThriftHiveMetastore.compact_args._Fields
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.metastore.api.ThriftHiveMetastore.compact_result._Fields
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.metastore.api.ThriftHiveMetastore.create_database_args._Fields
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.metastore.api.ThriftHiveMetastore.create_database_result._Fields
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.metastore.api.ThriftHiveMetastore.create_function_args._Fields
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.metastore.api.ThriftHiveMetastore.create_function_result._Fields
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.metastore.api.ThriftHiveMetastore.create_role_args._Fields
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.metastore.api.ThriftHiveMetastore.create_role_result._Fields
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.metastore.api.ThriftHiveMetastore.create_table_args._Fields
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.metastore.api.ThriftHiveMetastore.create_table_result._Fields
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.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.create_type_args._Fields
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.metastore.api.ThriftHiveMetastore.create_type_result._Fields
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.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result._Fields
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.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_function_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_function_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_partitions_req_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_partitions_req_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
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.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
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.metastore.api.ThriftHiveMetastore.exchange_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.exchange_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.fire_listener_event_args._Fields
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.metastore.api.ThriftHiveMetastore.fire_listener_event_result._Fields
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.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args._Fields
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.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result._Fields
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.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
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.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
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.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
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.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
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.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
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.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
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.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args._Fields
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.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result._Fields
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.metastore.api.ThriftHiveMetastore.get_database_args._Fields
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.metastore.api.ThriftHiveMetastore.get_database_result._Fields
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.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
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.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
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.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
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.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
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.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
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.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
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.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.get_function_args._Fields
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.metastore.api.ThriftHiveMetastore.get_function_result._Fields
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.metastore.api.ThriftHiveMetastore.get_functions_args._Fields
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.metastore.api.ThriftHiveMetastore.get_functions_result._Fields
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.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
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.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
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.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
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.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
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.metastore.api.ThriftHiveMetastore.get_next_notification_args._Fields
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.metastore.api.ThriftHiveMetastore.get_next_notification_result._Fields
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.metastore.api.ThriftHiveMetastore.get_open_txns_args._Fields
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.metastore.api.ThriftHiveMetastore.get_open_txns_info_args._Fields
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.metastore.api.ThriftHiveMetastore.get_open_txns_info_result._Fields
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.metastore.api.ThriftHiveMetastore.get_open_txns_result._Fields
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.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args._Fields
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.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
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.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
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.metastore.api.ThriftHiveMetastore.get_principals_in_role_args._Fields
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.metastore.api.ThriftHiveMetastore.get_principals_in_role_result._Fields
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.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
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.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
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.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args._Fields
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.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result._Fields
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.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
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.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
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.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
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.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
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.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args._Fields
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.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result._Fields
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.metastore.api.ThriftHiveMetastore.get_table_args._Fields
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.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result._Fields
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.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args._Fields
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.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result._Fields
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.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args._Fields
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.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result._Fields
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.metastore.api.ThriftHiveMetastore.get_table_result._Fields
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.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args._Fields
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.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result._Fields
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.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
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.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
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.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
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.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
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.metastore.api.ThriftHiveMetastore.get_type_args._Fields
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.metastore.api.ThriftHiveMetastore.get_type_result._Fields
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.metastore.api.ThriftHiveMetastore.getMetaConf_args._Fields
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.metastore.api.ThriftHiveMetastore.getMetaConf_result._Fields
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.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
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.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
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.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args._Fields
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.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result._Fields
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.metastore.api.ThriftHiveMetastore.grant_revoke_role_args._Fields
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.metastore.api.ThriftHiveMetastore.grant_revoke_role_result._Fields
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.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
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.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
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.metastore.api.ThriftHiveMetastore.heartbeat_args._Fields
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.metastore.api.ThriftHiveMetastore.heartbeat_result._Fields
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.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args._Fields
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.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result._Fields
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.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args._Fields
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.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result._Fields
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.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
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.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
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.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
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.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
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.metastore.api.ThriftHiveMetastore.lock_args._Fields
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.metastore.api.ThriftHiveMetastore.lock_result._Fields
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.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args._Fields
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.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result._Fields
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.metastore.api.ThriftHiveMetastore.open_txns_args._Fields
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.metastore.api.ThriftHiveMetastore.open_txns_result._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
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.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
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.metastore.api.ThriftHiveMetastore.rename_partition_args._Fields
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.metastore.api.ThriftHiveMetastore.rename_partition_result._Fields
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.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
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.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
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.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
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.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
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.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
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.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
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.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args._Fields
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.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result._Fields
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.metastore.api.ThriftHiveMetastore.set_ugi_args._Fields
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.metastore.api.ThriftHiveMetastore.set_ugi_result._Fields
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.metastore.api.ThriftHiveMetastore.setMetaConf_args._Fields
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.metastore.api.ThriftHiveMetastore.setMetaConf_result._Fields
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.metastore.api.ThriftHiveMetastore.show_compact_args._Fields
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.metastore.api.ThriftHiveMetastore.show_compact_result._Fields
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.metastore.api.ThriftHiveMetastore.show_locks_args._Fields
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.metastore.api.ThriftHiveMetastore.show_locks_result._Fields
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.metastore.api.ThriftHiveMetastore.unlock_args._Fields
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.metastore.api.ThriftHiveMetastore.unlock_result._Fields
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.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result._Fields
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.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args._Fields
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.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result._Fields
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.metastore.api.TxnAbortedException._Fields
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.metastore.api.TxnInfo._Fields
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.metastore.api.TxnOpenException._Fields
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.metastore.api.TxnState
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.metastore.api.Type._Fields
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.metastore.api.UnknownDBException._Fields
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.metastore.api.UnknownPartitionException._Fields
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.metastore.api.UnknownTableException._Fields
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.metastore.api.UnlockRequest._Fields
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.metastore.api.Version._Fields
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.metastore.events.PreEventContext.PreEventType
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.metastore.IExtrapolatePartStatus.AggrType
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.metastore.IExtrapolatePartStatus.ColStatType
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.metastore.parser.ExpressionTree.LogicalOperator
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.metastore.parser.ExpressionTree.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.metastore.TableType
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.metastore.txn.TxnHandler.DatabaseProduct
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.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.FileSinkOperator.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.FunctionInfo.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.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.JoinUtil.JoinResult
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.ReduceSinkOperator.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.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.spark.status.SparkJobState
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.ColumnVector.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.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.AcidUtils.Operation
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.CompressionCodec.Modifier
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.CompressionStrategy
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.EncodingStrategy
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.orc.OrcFile.WriterVersion
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.OrcProto.ColumnEncoding.Kind
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.OrcProto.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.OrcProto.Stream.Kind
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.OrcProto.Type.Kind
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.RecordIdentifier.Field
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.calcite.CalciteSemanticException.UnsupportedFeature
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.calcite.reloperators.HiveJoin.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.calcite.translator.HiveOpConverter.HIVEAGGOPMODE
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.ConstantPropagateProcCtx.ConstantPropagateOption
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.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.QBParseInfo.ClauseType
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.ReplicationSpec.KEY
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.ReplicationSpec.SCOPE
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.api.Adjacency._Fields
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.api.AdjacencyType
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.api.Graph._Fields
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.api.NodeType
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.api.Operator._Fields
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.api.OperatorType
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.api.Query._Fields
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.api.QueryPlan._Fields
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.api.Stage._Fields
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.api.StageType
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.api.Task._Fields
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.api.TaskType
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.Explain.Level
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.ReduceSinkDesc.ReducerTraits
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.plan.TezWork.VertexType
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.VectorMapJoinDesc.HashTableImplementationType
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.VectorMapJoinDesc.HashTableKeyType
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.VectorMapJoinDesc.HashTableKind
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.HiveAuthzSessionContext.CLIENT_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.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.HivePrivilegeObject.HivePrivObjectActionType
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.Operation2Privilege.IOType
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.OperationLog.LoggingLevel
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.udf.generic.GenericUDFNextDay.DayOfWeek
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.
values() - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
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.serde.test.ThriftTestObj._Fields
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.serde2.avro.AvroSerdeUtils.AvroTableProperties
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.serde2.dynamic_type.DynamicSerDeFieldRequiredness.RequirednessTypes
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.serde2.objectinspector.ObjectInspector.Category
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.serde2.objectinspector.ObjectInspectorFactory.ObjectInspectorOptions
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.serde2.objectinspector.ObjectInspectorUtils.ObjectInspectorCopyOption
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.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveGrouping
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.serde2.objectinspector.PrimitiveObjectInspector.PrimitiveCategory
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.serde2.thrift.test.Complex._Fields
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.serde2.thrift.test.IntString._Fields
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.serde2.thrift.test.MegaStruct._Fields
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.serde2.thrift.test.MiniStruct._Fields
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.serde2.thrift.test.MyEnum
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.serde2.thrift.test.PropValueUnion._Fields
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.serde2.thrift.test.SetIntString._Fields
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.service.HiveClusterStatus._Fields
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.service.HiveServerException._Fields
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.service.JobTrackerState
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.service.ThriftHive.clean_args._Fields
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.service.ThriftHive.clean_result._Fields
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.service.ThriftHive.execute_args._Fields
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.service.ThriftHive.execute_result._Fields
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.service.ThriftHive.fetchAll_args._Fields
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.service.ThriftHive.fetchAll_result._Fields
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.service.ThriftHive.fetchN_args._Fields
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.service.ThriftHive.fetchN_result._Fields
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.service.ThriftHive.fetchOne_args._Fields
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.service.ThriftHive.fetchOne_result._Fields
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.service.ThriftHive.getClusterStatus_args._Fields
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.service.ThriftHive.getClusterStatus_result._Fields
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.service.ThriftHive.getQueryPlan_args._Fields
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.service.ThriftHive.getQueryPlan_result._Fields
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.service.ThriftHive.getSchema_args._Fields
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.service.ThriftHive.getSchema_result._Fields
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.service.ThriftHive.getThriftSchema_args._Fields
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.service.ThriftHive.getThriftSchema_result._Fields
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.shims.HadoopShims.DirectCompressionType
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.shims.HadoopShims.HCatHadoopShims.PropertyName
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.shims.HadoopShims.JobTrackerState
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.shims.HadoopShims.StoragePolicyValue
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.thrift.HadoopThriftAuthBridge.Server.ServerMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.beeline.HiveSchemaHelper.NestedScriptParser.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.common.HiveCompat.CompatLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.common.util.HiveStringUtils.TraditionalBinaryPrefix
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.api.HCatClient.DropDBMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.api.HCatNotificationEvent.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.api.HCatTable.TableAttribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.api.HCatTable.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.common.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.common.HCatContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.data.schema.HCatFieldSchema.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.messaging.HCatEventMessage.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.streaming.TransactionBatch.TxnState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.templeton.LauncherDelegator.JobType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.templeton.TableDesc.SortDirectionDesc
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.hcatalog.templeton.tool.TempletonStorage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.auth.AuthenticationProviderFactory.AuthMethods
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.auth.HiveAuthFactory.AuthTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.auth.SaslQOP
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.FetchOrientation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.FetchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.GetInfoType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.operation.ClassicTableTypeMapping.ClassicTableTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.operation.TableTypeMappingFactory.TableTypeMappings
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.OperationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TArrayTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TBinaryColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TBoolColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TBoolValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TByteColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TByteValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCancelOperationResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTables_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCloseOperationResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TCloseSessionResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TColumnDesc._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TColumnValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TDoubleColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TDoubleValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TExecuteStatementResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TFetchOrientation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TFetchResultsResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetCatalogsResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetColumnsResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetDelegationTokenResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetFunctionsResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetInfoValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetOperationStatusResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetSchemasResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTablesResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTableTypesResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TGetTypeInfoResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.THandleIdentifier._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI16Column._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI16Value._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI32Column._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI32Value._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI64Column._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TI64Value._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TMapTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TOpenSessionResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TOperationHandle._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TOperationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TRow._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TRowSet._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TSessionHandle._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TStatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TStringColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TStringValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TStructTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTableSchema._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTypeDesc._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTypeId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifiers._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TTypeQualifierValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TUnionTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.cli.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.service.Service.STATE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.spark.client.JobHandle.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hive.spark.client.metrics.DataReadMethod
Returns an array containing the constants of this enum type, in the order they are declared.
valuesClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
valuesClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
valueSerializer - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
valuesTableConstructor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
valuesTableConstructor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
valueStore - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
valueStream - Variable in class org.apache.hadoop.hive.ql.io.orc.TreeReaderFactory.DecimalTreeReader
 
valueWriters - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
VARCHAR - Static variable in class org.apache.hive.hcatalog.data.DataType
 
VARCHAR_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
VARCHAR_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde2.avro.AvroSerDe
 
VARCHAR_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.Type.Kind
VARCHAR = 16;
VarCharScalarConcatStringGroupCol - 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.
VarCharScalarConcatStringGroupCol(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VarCharScalarConcatStringGroupCol
 
VarCharScalarConcatStringGroupCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VarCharScalarConcatStringGroupCol
 
VarCharScalarEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a == comparison on a vector of strings.
VarCharScalarEqualStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarEqualStringGroupColumn
 
VarCharScalarEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarEqualStringGroupColumn
 
VarCharScalarGreaterEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a >= comparison on a vector of strings.
VarCharScalarGreaterEqualStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterEqualStringGroupColumn
 
VarCharScalarGreaterEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterEqualStringGroupColumn
 
VarCharScalarGreaterStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a > comparison on a vector of strings.
VarCharScalarGreaterStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterStringGroupColumn
 
VarCharScalarGreaterStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarGreaterStringGroupColumn
 
VarCharScalarLessEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a <= comparison on a vector of strings.
VarCharScalarLessEqualStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessEqualStringGroupColumn
 
VarCharScalarLessEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessEqualStringGroupColumn
 
VarCharScalarLessStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a < comparison on a vector of strings.
VarCharScalarLessStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessStringGroupColumn
 
VarCharScalarLessStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarLessStringGroupColumn
 
VarCharScalarNotEqualStringGroupColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.gen
This is a generated class to evaluate a != comparison on a vector of strings.
VarCharScalarNotEqualStringGroupColumn(HiveVarchar, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarNotEqualStringGroupColumn
 
VarCharScalarNotEqualStringGroupColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.gen.VarCharScalarNotEqualStringGroupColumn
 
varcharTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
varcharTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
VarcharTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
 
VarcharTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
 
VarcharTypeInfo(int) - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.VarcharTypeInfo
 
varcharTypePattern - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
VariableSubstitution - Class in org.apache.hadoop.hive.ql.parse
 
VariableSubstitution() - Constructor for class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
varname - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
varPat - Static variable in class org.apache.hadoop.hive.conf.SystemVariables
 
vContext - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
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 of HiveDecimalWritable 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
 
VectorAppMasterEventOperator - Class in org.apache.hadoop.hive.ql.exec.vector
App Master Event operator implementation.
VectorAppMasterEventOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator
 
VectorAppMasterEventOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator
 
VectorAssignRow - Class in org.apache.hadoop.hive.ql.exec.vector
This class assigns specified columns of a row from a Writable row Object[].
VectorAssignRow() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow
 
VectorAssignRow.Assigner - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorAssignRow.BooleanAssigner - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorAssignRow.ByteAssigner - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorAssignRowDynBatch - Class in org.apache.hadoop.hive.ql.exec.vector
This class assigns specified columns of a VectorizedRowBatch row from a Writable row Object[].
VectorAssignRowDynBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRowDynBatch
 
VectorAssignRowSameBatch - Class in org.apache.hadoop.hive.ql.exec.vector
This class assigns specified columns of a VectorizedRowBatch row from a Writable row Object[].
VectorAssignRowSameBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAssignRowSameBatch
 
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
 
VectorColumnMapping - Class in org.apache.hadoop.hive.ql.exec.vector
This class collects column information for copying a row from one VectorizedRowBatch to same/another batch.
VectorColumnMapping(String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
vectorColumnMapping - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnMapping
 
vectorColumnNameMap - Variable in class org.apache.hadoop.hive.ql.plan.BaseWork
 
VectorColumnOrderedMap - Class in org.apache.hadoop.hive.ql.exec.vector
This class collects column information for mapping vector columns, including the hive type name.
VectorColumnOrderedMap(String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap
 
VectorColumnOrderedMap.Mapping - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorColumnOutputMapping - Class in org.apache.hadoop.hive.ql.exec.vector
This class collects column information for copying a row from one VectorizedRowBatch to same/another batch.
VectorColumnOutputMapping(String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnOutputMapping
 
VectorColumnSetInfo - Class in org.apache.hadoop.hive.ql.exec.vector
Class to keep information on a set of typed vector columns.
VectorColumnSetInfo(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo
 
VectorColumnSetInfo.KeyLookupHelper - Class in org.apache.hadoop.hive.ql.exec.vector
Helper class for looking up a key value based on key index.
VectorColumnSetInfo.KeyLookupHelper() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo.KeyLookupHelper
 
VectorColumnSourceMapping - Class in org.apache.hadoop.hive.ql.exec.vector
This class collects column information for copying a row from one VectorizedRowBatch to same/another batch.
VectorColumnSourceMapping(String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnSourceMapping
 
vectorColumnTypeMap - Variable in class org.apache.hadoop.hive.ql.plan.BaseWork
 
VectorCopyRow - Class in org.apache.hadoop.hive.ql.exec.vector
This class copies specified columns of a row from one VectorizedRowBatch to another.
VectorCopyRow() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow
 
VectorDesc - Interface in org.apache.hadoop.hive.ql.plan
 
VectorDeserializeRow - Class in org.apache.hadoop.hive.ql.exec.vector
This class deserializes a serialization format into a row of a VectorizedRowBatch.
VectorDeserializeRow(DeserializeRead) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow
 
VectorElt - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorElt(int[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorElt
 
VectorElt() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorElt
 
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.
VectorExtractRow - Class in org.apache.hadoop.hive.ql.exec.vector
This class extracts specified VectorizedRowBatch row columns into a Writable row Object[].
VectorExtractRow() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow
 
VectorExtractRow.BooleanExtractor - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorExtractRow.ByteExtractor - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorExtractRow.Extractor - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorExtractRow.Extractor(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow.Extractor
 
VectorExtractRowDynBatch - Class in org.apache.hadoop.hive.ql.exec.vector
This class extracts specified VectorizedRowBatch row columns into a Writable row Object[].
VectorExtractRowDynBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRowDynBatch
 
VectorExtractRowSameBatch - Class in org.apache.hadoop.hive.ql.exec.vector
This class extracts specified VectorizedRowBatch row columns into a Writable row Object[].
VectorExtractRowSameBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExtractRowSameBatch
 
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
 
VectorGroupByDesc - Class in org.apache.hadoop.hive.ql.plan
VectorGroupByDesc.
VectorGroupByDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.VectorGroupByDesc
 
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
 
VectorGroupKeyHelper - Class in org.apache.hadoop.hive.ql.exec.vector
Class for copying the group key from an input batch to an output batch.
VectorGroupKeyHelper(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorGroupKeyHelper
 
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(int) - 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(String, List<String>) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
VectorizationContext(String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
VectorizationContext(String, VectorizationContext) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
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
 
VectorizedParquetInputFormat - Class in org.apache.hadoop.hive.ql.io.parquet
Vectorized input format for Parquet files
VectorizedParquetInputFormat(ParquetInputFormat<ArrayWritable>) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.VectorizedParquetInputFormat
 
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
 
VectorMapJoinBaseOperator - Class in org.apache.hadoop.hive.ql.exec.vector
The *NON-NATIVE* base vector map join operator class used by VectorMapJoinOperator and VectorMapJoinOuterFilteredOperator.
VectorMapJoinBaseOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
VectorMapJoinBaseOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
VectorMapJoinBytesHashMap - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinBytesHashMultiSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinBytesHashSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinBytesHashTable - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinCommonOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class is common operator class for native vectorized map join.
VectorMapJoinCommonOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
VectorMapJoinCommonOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
VectorMapJoinDesc - Class in org.apache.hadoop.hive.ql.plan
VectorGroupByDesc.
VectorMapJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
VectorMapJoinDesc(VectorMapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.VectorMapJoinDesc
 
VectorMapJoinDesc.HashTableImplementationType - Enum in org.apache.hadoop.hive.ql.plan
 
VectorMapJoinDesc.HashTableKeyType - Enum in org.apache.hadoop.hive.ql.plan
 
VectorMapJoinDesc.HashTableKind - Enum in org.apache.hadoop.hive.ql.plan
 
VectorMapJoinFastBytesHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastBytesHashMap(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMap
 
VectorMapJoinFastBytesHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastBytesHashMultiSet(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMultiSet
 
VectorMapJoinFastBytesHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastBytesHashSet(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashSet
 
VectorMapJoinFastBytesHashTable - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastBytesHashTable(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashTable
 
VectorMapJoinFastBytesHashUtil - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastBytesHashUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashUtil
 
VectorMapJoinFastHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashMap(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashMap
 
VectorMapJoinFastHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashMultiSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashMultiSet
 
VectorMapJoinFastHashMultiSet.HashMultiSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashSet
 
VectorMapJoinFastHashSet.HashSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashTable - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastHashTable(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
VectorMapJoinFastHashTableLoader - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
HashTableLoader for Tez constructs the hashtable from records read from a broadcast edge.
VectorMapJoinFastHashTableLoader() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTableLoader
 
VectorMapJoinFastIntHashUtil - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastIntHashUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastIntHashUtil
 
VectorMapJoinFastKeyStore - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastKeyStore(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastKeyStore
 
VectorMapJoinFastKeyStore(WriteBuffers) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastKeyStore
 
VectorMapJoinFastLongHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastLongHashMap(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap
 
VectorMapJoinFastLongHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastLongHashMultiSet(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet
 
VectorMapJoinFastLongHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastLongHashSet(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet
 
VectorMapJoinFastLongHashTable - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastLongHashTable(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable
 
VectorMapJoinFastLongHashUtil - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastLongHashUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashUtil
 
VectorMapJoinFastMultiKeyHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastMultiKeyHashMap(int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashMap
 
VectorMapJoinFastMultiKeyHashMap(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashMap
 
VectorMapJoinFastMultiKeyHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastMultiKeyHashMultiSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashMultiSet
 
VectorMapJoinFastMultiKeyHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastMultiKeyHashSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashSet
 
VectorMapJoinFastStringCommon - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastStringCommon(boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringCommon
 
VectorMapJoinFastStringHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastStringHashMap(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashMap
 
VectorMapJoinFastStringHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastStringHashMultiSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashMultiSet
 
VectorMapJoinFastStringHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastStringHashSet(boolean, int, float, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringHashSet
 
VectorMapJoinFastTableContainer - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
HashTableLoader for Tez constructs the hashtable from records read from a broadcast edge.
VectorMapJoinFastTableContainer(MapJoinDesc, Configuration, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
VectorMapJoinFastValueStore - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastValueStore(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore
 
VectorMapJoinFastValueStore.HashMapResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast
 
VectorMapJoinFastValueStore.HashMapResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore.HashMapResult
 
VectorMapJoinGenerateResultOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class has methods for generating vectorized join results and forwarding batchs.
VectorMapJoinGenerateResultOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
VectorMapJoinGenerateResultOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
VectorMapJoinHashMap - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashMapResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashMapResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult
 
VectorMapJoinHashMultiSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashMultiSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashMultiSetResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMultiSetResult
 
VectorMapJoinHashSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashSetResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashSetResult
 
vectorMapJoinHashTable() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer
 
VectorMapJoinHashTable - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
vectorMapJoinHashTable() - Method in interface org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinTableContainer
 
vectorMapJoinHashTable - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
VectorMapJoinHashTableResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinHashTableResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult
 
VectorMapJoinInnerBigOnlyGenerateResultOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class has methods for generating vectorized join results for the big table only variation of inner joins.
VectorMapJoinInnerBigOnlyGenerateResultOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
VectorMapJoinInnerBigOnlyGenerateResultOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator
 
VectorMapJoinInnerBigOnlyLongOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerBigOnlyLongOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyLongOperator
 
VectorMapJoinInnerBigOnlyLongOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyLongOperator
 
VectorMapJoinInnerBigOnlyMultiKeyOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerBigOnlyMultiKeyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyMultiKeyOperator
 
VectorMapJoinInnerBigOnlyMultiKeyOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyMultiKeyOperator
 
VectorMapJoinInnerBigOnlyStringOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerBigOnlyStringOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyStringOperator
 
VectorMapJoinInnerBigOnlyStringOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyStringOperator
 
VectorMapJoinInnerGenerateResultOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class has methods for generating vectorized join results for inner joins.
VectorMapJoinInnerGenerateResultOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
VectorMapJoinInnerGenerateResultOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator
 
VectorMapJoinInnerLongOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerLongOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerLongOperator
 
VectorMapJoinInnerLongOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerLongOperator
 
VectorMapJoinInnerMultiKeyOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerMultiKeyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerMultiKeyOperator
 
VectorMapJoinInnerMultiKeyOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerMultiKeyOperator
 
VectorMapJoinInnerStringOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinInnerStringOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerStringOperator
 
VectorMapJoinInnerStringOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerStringOperator
 
VectorMapJoinLeftSemiGenerateResultOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class has methods for generating vectorized join results for left semi joins.
VectorMapJoinLeftSemiGenerateResultOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
VectorMapJoinLeftSemiGenerateResultOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator
 
VectorMapJoinLeftSemiLongOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinLeftSemiLongOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiLongOperator
 
VectorMapJoinLeftSemiLongOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiLongOperator
 
VectorMapJoinLeftSemiMultiKeyOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinLeftSemiMultiKeyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiMultiKeyOperator
 
VectorMapJoinLeftSemiMultiKeyOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiMultiKeyOperator
 
VectorMapJoinLeftSemiStringOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinLeftSemiStringOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiStringOperator
 
VectorMapJoinLeftSemiStringOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiStringOperator
 
VectorMapJoinLongHashMap - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinLongHashMultiSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinLongHashSet - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapJoinLongHashTable - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
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
 
VectorMapJoinOptimizedCreateHashTable - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedCreateHashTable() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedCreateHashTable
 
VectorMapJoinOptimizedHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashMap(MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap
 
VectorMapJoinOptimizedHashMap.HashMapResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashMap.HashMapResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMap.HashMapResult
 
VectorMapJoinOptimizedHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashMultiSet(MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet
 
VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashMultiSet.HashMultiSetResult
 
VectorMapJoinOptimizedHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashSet(MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet
 
VectorMapJoinOptimizedHashSet.HashSetResult - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashSet.HashSetResult() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashSet.HashSetResult
 
VectorMapJoinOptimizedHashTable - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashTable(MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable
 
VectorMapJoinOptimizedHashTable.SerializedBytes - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedHashTable.SerializedBytes() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedHashTable.SerializedBytes
 
VectorMapJoinOptimizedLongCommon - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedLongCommon(boolean, boolean, VectorMapJoinDesc.HashTableKeyType) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongCommon
 
VectorMapJoinOptimizedLongHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedLongHashMap(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMap
 
VectorMapJoinOptimizedLongHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedLongHashMultiSet(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashMultiSet
 
VectorMapJoinOptimizedLongHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedLongHashSet(boolean, boolean, VectorMapJoinDesc.HashTableKeyType, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedLongHashSet
 
VectorMapJoinOptimizedMultiKeyHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedMultiKeyHashMap(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedMultiKeyHashMap
 
VectorMapJoinOptimizedMultiKeyHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedMultiKeyHashMultiSet(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedMultiKeyHashMultiSet
 
VectorMapJoinOptimizedMultiKeyHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedMultiKeyHashSet(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedMultiKeyHashSet
 
VectorMapJoinOptimizedStringCommon - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedStringCommon(boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringCommon
 
VectorMapJoinOptimizedStringHashMap - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedStringHashMap(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashMap
 
VectorMapJoinOptimizedStringHashMultiSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedStringHashMultiSet(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashMultiSet
 
VectorMapJoinOptimizedStringHashSet - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized
 
VectorMapJoinOptimizedStringHashSet(boolean, MapJoinTableContainer, MapJoinTableContainer.ReusableGetAdaptor) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedStringHashSet
 
VectorMapJoinOuterFilteredOperator - Class in org.apache.hadoop.hive.ql.exec.vector
This is the *NON-NATIVE* vector map join operator for just LEFT OUTER JOIN and filtered.
VectorMapJoinOuterFilteredOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator
 
VectorMapJoinOuterFilteredOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator
 
VectorMapJoinOuterGenerateResultOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
This class has methods for generating vectorized join results for outer joins.
VectorMapJoinOuterGenerateResultOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
VectorMapJoinOuterGenerateResultOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator
 
VectorMapJoinOuterLongOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinOuterLongOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterLongOperator
 
VectorMapJoinOuterLongOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterLongOperator
 
VectorMapJoinOuterMultiKeyOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinOuterMultiKeyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterMultiKeyOperator
 
VectorMapJoinOuterMultiKeyOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterMultiKeyOperator
 
VectorMapJoinOuterStringOperator - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
 
VectorMapJoinOuterStringOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterStringOperator
 
VectorMapJoinOuterStringOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterStringOperator
 
VectorMapJoinRowBytesContainer - Class in org.apache.hadoop.hive.ql.exec.vector.mapjoin
An eager bytes container that puts row bytes to an output stream.
VectorMapJoinRowBytesContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer
 
VectorMapJoinTableContainer - Interface in org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable
 
VectorMapOperator - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorMapOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator
 
vectorMode - Variable in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
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
 
vectorScratchColumnTypeMap - Variable in class org.apache.hadoop.hive.ql.plan.BaseWork
 
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
 
VectorSerializeRow - Class in org.apache.hadoop.hive.ql.exec.vector
This class serializes columns from a row in a VectorizedRowBatch into a serialization format.
VectorSerializeRow(SerializeWrite) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow
 
VectorSerializeRowNoNulls - Class in org.apache.hadoop.hive.ql.exec.vector
This class serializes columns from a row in a VectorizedRowBatch into a serialization format.
VectorSerializeRowNoNulls(SerializeWrite) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRowNoNulls
 
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
 
VectorUDAFAvgDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
Generated from template VectorUDAFAvg.txt.
VectorUDAFAvgDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgDouble
 
VectorUDAFAvgDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgDouble
 
VectorUDAFAvgLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
Generated from template VectorUDAFAvg.txt.
VectorUDAFAvgLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
VectorUDAFAvgLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgLong
 
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
 
VectorUDAFCountMerge - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
VectorUDAFCountMerge.
VectorUDAFCountMerge(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountMerge
 
VectorUDAFCountMerge() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountMerge
 
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
 
VectorUDAFMaxDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMaxDecimal.
VectorUDAFMaxDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
VectorUDAFMaxDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDecimal
 
VectorUDAFMaxDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMaxDouble.
VectorUDAFMaxDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
VectorUDAFMaxDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxDouble
 
VectorUDAFMaxLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMaxLong.
VectorUDAFMaxLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
VectorUDAFMaxLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxLong
 
VectorUDAFMaxString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMaxString.
VectorUDAFMaxString(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
VectorUDAFMaxString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMaxString
 
VectorUDAFMinDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMinDecimal.
VectorUDAFMinDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
VectorUDAFMinDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDecimal
 
VectorUDAFMinDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMinDouble.
VectorUDAFMinDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
VectorUDAFMinDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinDouble
 
VectorUDAFMinLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMinLong.
VectorUDAFMinLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
VectorUDAFMinLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinLong
 
VectorUDAFMinString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFMinString.
VectorUDAFMinString(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
VectorUDAFMinString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFMinString
 
VectorUDAFStdPopDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdPopDecimal.
VectorUDAFStdPopDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
VectorUDAFStdPopDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDecimal
 
VectorUDAFStdPopDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdPopDouble.
VectorUDAFStdPopDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
VectorUDAFStdPopDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopDouble
 
VectorUDAFStdPopLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdPopLong.
VectorUDAFStdPopLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
VectorUDAFStdPopLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdPopLong
 
VectorUDAFStdSampDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdSampDecimal.
VectorUDAFStdSampDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
VectorUDAFStdSampDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDecimal
 
VectorUDAFStdSampDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdSampDouble.
VectorUDAFStdSampDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
VectorUDAFStdSampDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampDouble
 
VectorUDAFStdSampLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFStdSampLong.
VectorUDAFStdSampLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
VectorUDAFStdSampLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFStdSampLong
 
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
 
VectorUDAFSumDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFSumDouble.
VectorUDAFSumDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
VectorUDAFSumDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumDouble
 
VectorUDAFSumLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFSumLong.
VectorUDAFSumLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
VectorUDAFSumLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFSumLong
 
VectorUDAFVarPopDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarPopDecimal.
VectorUDAFVarPopDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
VectorUDAFVarPopDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDecimal
 
VectorUDAFVarPopDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarPopDouble.
VectorUDAFVarPopDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
VectorUDAFVarPopDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopDouble
 
VectorUDAFVarPopLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarPopLong.
VectorUDAFVarPopLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
VectorUDAFVarPopLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarPopLong
 
VectorUDAFVarSampDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarSampDecimal.
VectorUDAFVarSampDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
VectorUDAFVarSampDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDecimal
 
VectorUDAFVarSampDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarSampDouble.
VectorUDAFVarSampDouble(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
VectorUDAFVarSampDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampDouble
 
VectorUDAFVarSampLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen
VectorUDAFVarSampLong.
VectorUDAFVarSampLong(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
VectorUDAFVarSampLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen.VectorUDAFVarSampLong
 
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
 
verbose(String) - Method in class org.apache.hive.beeline.Commands
 
verboseLayout - Static variable in class org.apache.hive.service.cli.CLIServiceUtils
 
verifyActionable() - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
 
verifyAndExtract(String) - Method in class org.apache.hive.service.CookieSigner
Verify a signed string and extracts the original string.
verifyAndSet(String, String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
verifyDdlParam(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Verify that the parameter exists and is a simple DDL identifier name.
verifyMonotonicallyIncreasing(int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator
 
verifyObjectClassType(Class<?>) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
verifyParam(String, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Verify that the parameter exists.
verifyParam(List<String>, String) - Method in class org.apache.hive.hcatalog.templeton.Server
Verify that the parameter exists.
verifyProxyAccess(String, String, String, HiveConf) - Static method in class org.apache.hive.service.auth.HiveAuthFactory
 
verifySchema() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
verifySchema() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
verifySchemaVersion() - Method in class org.apache.hive.beeline.HiveSchemaTool
check if the current schema version in metastore matches the Hive version
verifySuccess(TStatus) - Static method in class org.apache.hive.jdbc.Utils
 
verifySuccess(TStatus, boolean) - Static method in class org.apache.hive.jdbc.Utils
 
verifySuccessWithInfo(TStatus) - Static method in class org.apache.hive.jdbc.Utils
 
verifyUser() - Method in class org.apache.hive.hcatalog.templeton.Server
Verify that we have a valid user.
Version - Class in org.apache.hadoop.hive.metastore.api
 
Version() - Constructor for class org.apache.hadoop.hive.metastore.api.Version
 
Version(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.Version
 
Version(Version) - Constructor for class org.apache.hadoop.hive.metastore.api.Version
Performs a deep copy on other.
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.
VERSION - Static variable in class org.apache.hive.hcatalog.templeton.Server
 
version() - Method in class org.apache.hive.hcatalog.templeton.Server
Check the version(s) supported by this server.
Version._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
VERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
VersionDelegator - Class in org.apache.hive.hcatalog.templeton
Find the version of Hive, Hadoop, or Pig that is being used in this interface.
VersionDelegator(AppConfig) - Constructor for class org.apache.hive.hcatalog.templeton.VersionDelegator
 
Vertex - Class in org.apache.hadoop.hive.common.jsonexplain.tez
 
Vertex(String, JSONObject) - Constructor for class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
vertexObject - Variable in class org.apache.hadoop.hive.common.jsonexplain.tez.Vertex
 
vExpressions - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
viewName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
viewName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
viewPartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
VIRTUAL_COLUMN_NAMES - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
VirtualColumn - Class in org.apache.hadoop.hive.ql.metadata
 
virtualTableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
virtualTableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
VISIBILITY_LABEL_KEY - Static variable in class org.apache.hadoop.hive.accumulo.serde.AccumuloSerDeParameters
 
visit(ExpressionTree.LeafNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeVisitor
 
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.calcite.HiveCalciteUtil.ConstantFinder
 
visitCall(RexCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractPartPruningPredicate
 
visitCall(RexCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractRemainingPredicate
 
visitCall(RexCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.stats.FilterSelectivityEstimator
 
visitCall(RexCall) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
TODO: Handle 1) cast 2) Field Access 3) Windowing Over() 4, Windowing Agg Call
visitChild(int, RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveRelNode.Implementor
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitInputRef(RexInputRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitInputRef(RexInputRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractPartPruningPredicate
 
visitInputRef(RexInputRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractRemainingPredicate
 
visitInputRef(RexInputRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
visitLiteral(RexLiteral) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitLiteral(RexLiteral) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractPartPruningPredicate
 
visitLiteral(RexLiteral) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPrune.ExtractRemainingPredicate
 
visitLiteral(RexLiteral) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
TODO: 1.
visitLocalRef(RexLocalRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitOver(RexOver) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
visitOver(RexOver) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter
 
visitRangeRef(RexRangeRef) - Method in class org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil.ConstantFinder
 
VOID_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.serdeConstants
 
VoidObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A VoidObjectInspector can inspect a void object.
voidTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
voidTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
vOutContext - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator
 
vOutContext - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 
vrbCtx - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator
 

W

w - Variable in class org.apache.hadoop.hive.ql.plan.SparkWork.Dependency
 
w - Variable in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
WadlConfig - Class in org.apache.hive.hcatalog.templeton
Simple class that incorporates javadoc information into the wadl produced by jersey.
WadlConfig() - Constructor for class org.apache.hive.hcatalog.templeton.WadlConfig
 
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.optimizer.ConstantPropagate.ConstantPropagateWalker
 
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.spark.GenSparkWorkWalker
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.
Warehouse - Class in org.apache.hadoop.hive.metastore
This class represents a warehouse where data of Hive tables is stored
Warehouse(Configuration) - Constructor for class org.apache.hadoop.hive.metastore.Warehouse
 
warned - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator
 
warningChain - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
wasNull - Variable in class org.apache.hive.jdbc.HiveBaseResultSet
 
wasNull() - Method in class org.apache.hive.jdbc.HiveBaseResultSet
 
wasNull() - Method in class org.apache.hive.jdbc.HiveCallableStatement
 
WATCHER_TIMEOUT_SECS - Static variable in interface org.apache.hive.hcatalog.templeton.tool.JobSubmissionConstants
 
we - Variable in class org.apache.hive.hcatalog.data.transfer.HCatWriter
 
WEBHCAT_CONF_DIR - Static variable in class org.apache.hive.hcatalog.templeton.AppConfig
 
WebHCatJTShim20S - Class in org.apache.hadoop.mapred
This is in org.apache.hadoop.mapred package because it relies on JobSubmissionProtocol which is package private
WebHCatJTShim20S(Configuration, UserGroupInformation) - Constructor for class org.apache.hadoop.mapred.WebHCatJTShim20S
Create a connection to the Job Tracker.
WebHCatJTShim23 - Class in org.apache.hadoop.mapred
 
WebHCatJTShim23(Configuration, UserGroupInformation) - Constructor for class org.apache.hadoop.mapred.WebHCatJTShim23
Create a connection to the Job Tracker.
whenExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
whenExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
whereClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
whereClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
willSpill() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
window_clause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_clause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_defn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_defn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_frame() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_frame() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_frame_boundary() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_frame_boundary() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_frame_start_boundary() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_frame_start_boundary() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_range_expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_range_expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_specification() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_specification() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
window_value_expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
window_value_expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
WindowExpressionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
WindowExpressionDef() - 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
 
WindowFunctionInfo(boolean, String, GenericUDAFResolver, FunctionInfo.FunctionResource[]) - Constructor for class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
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.HiveDecimalValueBoundaryScanner - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.HiveDecimalValueBoundaryScanner(BoundaryDef, PTFInvocationSpec.Order, PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.HiveDecimalValueBoundaryScanner
 
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.WindowingIterator - Class in org.apache.hadoop.hive.ql.udf.ptf
 
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
 
withAdminOption() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
withClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
withDatabase(String) - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
withDatabase(String) - Method in class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
withDbNameMapping(Function<String, String>) - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Allows a user to specify a db name mapping, where the the function provided maps the name of the db in the source warehouse to the name of the db in the dest warehouse.
withDstStagingDirProvider(StagingDirectoryProvider) - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
withFilter(String) - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
withGrantOption() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
withKeyType(PrimitiveTypeInfo) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.MapBuilder
 
withPartition(Map<String, String>) - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
withPartition(Map<String, String>) - Method in class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
withRegion(String) - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
withRegion(String) - Method in class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
withSrcStagingDirProvider(StagingDirectoryProvider) - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
withTable(String) - Method in class org.apache.hive.hcatalog.data.transfer.ReadEntity.Builder
 
withTable(String) - Method in class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
withTableNameMapping(Function<String, String>) - Method in class org.apache.hive.hcatalog.api.repl.ReplicationTask
Allows a user to specify a table name mapping, where the the function provided maps the name of the table in the source warehouse to the name of the table in the dest warehouse.
withValueSchema(HCatSchema) - Method in class org.apache.hive.hcatalog.data.schema.HCatSchemaUtils.MapBuilder
 
wordArrayToBitmap(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
WordCountReduce - Class in org.apache.hadoop.hive.contrib.mr.example
Example Reducer (WordCount).
work - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
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
 
workerKeepAliveTime - Variable in class org.apache.hive.service.cli.thrift.ThriftCLIService
 
workGraph - Variable in class org.apache.hadoop.hive.ql.plan.SparkWork
 
WORKING_RESPONSE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
WORKING_STATE - Static variable in class org.apache.hadoop.hive.metastore.txn.TxnHandler
 
workWithUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
workWithUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext
 
wrap(byte[], int, int) - Method in class org.apache.hive.service.auth.PlainSaslServer
 
wrapNonAssumingProcessor(TProcessor) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
Wrap a TProcessor to capture the client information like connecting userid, ip etc
wrapped - Variable in class org.apache.hadoop.hive.thrift.TFilterTransport
 
wrappedEval - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator
 
wrapProcessor(TProcessor) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
Wrap a TProcessor in such a way that, before processing any RPC, it assumes the UserGroupInformation of the user authenticated by the SASL transport.
writableBinaryObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableBinaryObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableBinaryObjectInspector inspects a BytesWritable Object.
writableBooleanObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableBooleanObjectInspector inspects a BooleanWritable Object.
writableByteObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableByteObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableByteObjectInspector inspects a ByteWritable Object.
WritableByteObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableByteObjectInspector
 
WritableConstantBinaryObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantBinaryObjectInspector is a WritableBinaryObjectInspector that implements ConstantObjectInspector.
WritableConstantBinaryObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantBinaryObjectInspector
 
WritableConstantBinaryObjectInspector(BytesWritable) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantBinaryObjectInspector
 
WritableConstantBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantBooleanObjectInspector is a WritableBooleanObjectInspector that implements ConstantObjectInspector.
WritableConstantBooleanObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantBooleanObjectInspector
 
WritableConstantByteObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantByteObjectInspector is a WritableByteObjectInspector that implements ConstantObjectInspector.
WritableConstantByteObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantByteObjectInspector
 
WritableConstantDateObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantDateObjectInspector is a WritableDateObjectInspector that implements ConstantObjectInspector.
WritableConstantDateObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantDateObjectInspector
 
WritableConstantDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantDoubleObjectInspector is a WritableDoubleObjectInspector that implements ConstantObjectInspector.
WritableConstantDoubleObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantDoubleObjectInspector
 
WritableConstantFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantFloatObjectInspector is a WritableFloatObjectInspector that implements ConstantObjectInspector.
WritableConstantFloatObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantFloatObjectInspector
 
WritableConstantHiveCharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantHiveCharObjectInspector is a WritableHiveCharObjectInspector that implements ConstantObjectInspector.
WritableConstantHiveDecimalObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantHiveDecimalObjectInspector is a WritableHiveDecimalObjectInspector that implements ConstantObjectInspector.
WritableConstantHiveDecimalObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveDecimalObjectInspector
 
WritableConstantHiveIntervalDayTimeObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableConstantHiveIntervalDayTimeObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveIntervalDayTimeObjectInspector
 
WritableConstantHiveIntervalYearMonthObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableConstantHiveIntervalYearMonthObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantHiveIntervalYearMonthObjectInspector
 
WritableConstantHiveVarcharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantHiveVarcharObjectInspector is a WritableHiveVarcharObjectInspector that implements ConstantObjectInspector.
WritableConstantIntObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantIntObjectInspector is a WritableIntObjectInspector that implements ConstantObjectInspector.
WritableConstantIntObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantIntObjectInspector
 
WritableConstantLongObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantLongObjectInspector is a WritableLongObjectInspector that implements ConstantObjectInspector.
WritableConstantLongObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantLongObjectInspector
 
WritableConstantShortObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantShortObjectInspector is a WritableShortObjectInspector that implements ConstantObjectInspector.
WritableConstantShortObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantShortObjectInspector
 
WritableConstantStringObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantStringObjectInspector is a WritableStringObjectInspector that implements ConstantObjectInspector.
WritableConstantStringObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantStringObjectInspector
 
WritableConstantTimestampObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableConstantTimestampObjectInspector is a WritableTimestampObjectInspector that implements ConstantObjectInspector.
WritableConstantTimestampObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableConstantTimestampObjectInspector
 
writableDateObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableDateObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableDateObjectInspector inspects a DateWritable Object.
WritableDateObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableDateObjectInspector
 
writableDoubleObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableDoubleObjectInspector inspects a DoubleWritable Object.
writableFloatObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A FloatObjectInspector inspects a FloatWritable Object.
writableHiveCharObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableHiveCharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableHiveCharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
WritableHiveCharObjectInspector(CharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveCharObjectInspector
 
writableHiveDecimalObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableHiveDecimalObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableHiveDecimalObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
WritableHiveDecimalObjectInspector(DecimalTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveDecimalObjectInspector
 
writableHiveIntervalDayTimeObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableHiveIntervalDayTimeObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableHiveIntervalDayTimeObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalDayTimeObjectInspector
 
writableHiveIntervalYearMonthObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableHiveIntervalYearMonthObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableHiveIntervalYearMonthObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveIntervalYearMonthObjectInspector
 
writableHiveVarcharObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableHiveVarcharObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableHiveVarcharObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
WritableHiveVarcharObjectInspector(VarcharTypeInfo) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableHiveVarcharObjectInspector
 
writableIntObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableIntObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableIntObjectInspector inspects a IntWritable Object.
writableLongObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableLongObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableLongObjectInspector inspects a LongWritable Object.
writableShortObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableShortObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableShortObjectInspector inspects a ShortWritable Object.
writableStringObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableStringObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableStringObjectInspector inspects a Text Object.
writableTimestampObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableTimestampObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
 
WritableTimestampObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableTimestampObjectInspector
 
writableVoidObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
WritableVoidObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A WritableVoidObjectInspector inspects a NullWritable Object.
write(DataOutput) - Method in class org.apache.hadoop.hive.accumulo.AccumuloHiveRow
 
write(DataOutput) - Method in class org.apache.hadoop.hive.accumulo.mr.HiveAccumuloSplit
 
write(DataInput, int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
write(int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
write(byte[], int, int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
write(Writable) - Method in class org.apache.hadoop.hive.contrib.fileformat.base64.Base64TextOutputFormat.Base64RecordWriter
 
write(Object) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a Java object as a typed bytes sequence.
write(Writable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordWriter
 
write(Writable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
write(int) - Method in class org.apache.hadoop.hive.hbase.DataOutputOutputStream
 
write(DataOutput) - Method in class org.apache.hadoop.hive.hbase.HBaseSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.hbase.PutWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.hbase.ResultWritable
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AbortTxnRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddDynamicPartitions
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AddPartitionsResult
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.AggrStats
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CheckLockRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatistics
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CommitTxnRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CompactionRequest
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Date
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DateColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Decimal
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsExpr
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.DropPartitionsResult
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.EnvironmentContext
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FireEventResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Function
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.InsertEventRequestData
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidInputException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidPartitionException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockComponent
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LockResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.LongColumnStatsData
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchLockException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchTxnException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEvent
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.NotificationEventResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.OpenTxnsResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsByExprResult
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpec
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionsStatsResult
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PartitionWithoutSD
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ResourceUri
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.RolePrincipalGrant
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponse
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SkewedInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StringColumnStatsData
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TableStatsResult
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.abort_txn_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_dynamic_partitions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_pspec_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_req_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partitions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_function_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partitions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_cascade_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.check_lock_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.commit_txn_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.compact_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_function_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_partition_column_statistics_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.delete_table_column_statistics_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_function_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partitions_req_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.exchange_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.fire_listener_event_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_aggr_stats_for_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_current_notificationEventId_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_function_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_functions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_next_notification_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_info_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_open_txns_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_part_specs_by_filter_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_column_statistics_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_expr_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_pspec_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_statistics_req_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_principals_in_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_grants_for_principal_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_with_environment_context_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_column_statistics_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_names_by_filter_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_objects_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_statistics_req_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.getMetaConf_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_revoke_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.heartbeat_txn_range_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.isPartitionMarkedForEvent_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.lock_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.markPartitionForEvent_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.open_txns_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_has_valid_characters_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.rename_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_aggr_stats_for_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.set_ugi_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.setMetaConf_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_compact_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.show_locks_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.unlock_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_partition_column_statistics_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.update_table_column_statistics_result
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.TxnAbortedException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.TxnInfo
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.TxnOpenException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownPartitionException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.UnlockRequest
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Deprecated.
 
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.FlatRowContainer
 
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.MapJoinKeyObject
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer
 
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.tez.CustomVertexConfiguration
 
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(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
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(K, V) - Method in class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat.IgnoreKeyWriter
Deprecated.
 
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.OrcFileKeyWrapper
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper
 
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(ParquetHiveRecord) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriter
It writes all record values to the Parquet RecordConsumer.
write(ParquetHiveRecord) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
write(Void, ParquetHiveRecord) - 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
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.avro.AvroGenericRecordWritable
 
write(int) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
write(byte[]) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
write(byte[], int, int) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveBaseCharWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.ParquetHiveRecord
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
write(OutputStream) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MegaStruct
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.MiniStruct
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.SetIntString
 
write(int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
write(byte[]) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
write(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.clean_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
write(DataOutput) - Method in class org.apache.hadoop.hive.shims.CombineHiveKey
 
write(DataOutput) - Method in class org.apache.hadoop.hive.shims.HadoopShimsSecure.InputSplitShim
 
write(byte[]) - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
write(byte[], int, int) - Method in class org.apache.hadoop.hive.thrift.TFilterTransport
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropDatabaseCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropPartitionCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.DropTableCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.ExportCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.ImportCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.api.repl.commands.NoopCommand
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.data.DefaultHCatRecord
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.data.LazyHCatRecord
 
write(Iterator<HCatRecord>) - Method in class org.apache.hive.hcatalog.data.transfer.HCatWriter
This method should be used at slave needs to perform writes.
write(Iterator<HCatRecord>) - Method in class org.apache.hive.hcatalog.data.transfer.impl.HCatOutputFormatWriter
 
write(DataOutput) - Method in class org.apache.hive.hcatalog.mapreduce.HCatSplit
 
write(String, K, V, TaskInputOutputContext) - Static method in class org.apache.hive.hcatalog.mapreduce.MultiOutputFormat
Write the output key and value using the OutputFormat defined by the alias.
write(long, byte[]) - Method in class org.apache.hive.hcatalog.streaming.DelimitedInputWriter
 
write(long, byte[]) - Method in interface org.apache.hive.hcatalog.streaming.RecordWriter
Writes using a hive RecordUpdater
write(long, byte[]) - Method in class org.apache.hive.hcatalog.streaming.StrictJsonWriter
 
write(long, byte[]) - Method in class org.apache.hive.hcatalog.streaming.StrictRegexWriter
 
write(byte[]) - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Write record using RecordWriter
write(Collection<byte[]>) - Method in interface org.apache.hive.hcatalog.streaming.TransactionBatch
Write records using RecordWriter
write(int) - Method in class org.apache.hive.hcatalog.templeton.MaxByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class org.apache.hive.hcatalog.templeton.MaxByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
write(DataOutput) - Method in class org.apache.hive.hcatalog.templeton.tool.NullSplit
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TArrayTypeEntry
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBinaryColumn
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBoolColumn
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TBoolValue
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TByteColumn
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TByteValue
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelDelegationTokenResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCancelOperationResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelDelegationToken_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CancelOperation_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseOperation_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.CloseSession_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.ExecuteStatement_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.FetchResults_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetCatalogs_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetColumns_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetDelegationToken_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetFunctions_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetInfo_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetOperationStatus_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetResultSetMetadata_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetSchemas_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTables_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTableTypes_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.GetTypeInfo_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.OpenSession_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_args
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.RenewDelegationToken_result
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseOperationResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCloseSessionResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TColumnDesc
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TDoubleColumn
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TDoubleValue
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TExecuteStatementResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TFetchResultsResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetCatalogsResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetColumnsResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetDelegationTokenResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetFunctionsResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetInfoResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetOperationStatusResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetResultSetMetadataResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetSchemasResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTablesReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTablesResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTableTypesResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TGetTypeInfoResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.THandleIdentifier
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI16Column
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI16Value
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI32Column
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI32Value
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI64Column
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TI64Value
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TMapTypeEntry
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOpenSessionResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TOperationHandle
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TPrimitiveTypeEntry
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenReq
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRenewDelegationTokenResp
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRow
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TRowSet
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TSessionHandle
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStatus
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStringColumn
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStringValue
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TStructTypeEntry
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTableSchema
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeDesc
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TTypeQualifiers
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TUnionTypeEntry
 
write(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TUserDefinedTypeEntry
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.abort_txn_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partitions_req_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_function_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partitions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_cascade_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.check_lock_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.commit_txn_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.compact_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_function_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_function_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partitions_req_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.exchange_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.fire_listener_event_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_current_notificationEventId_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_function_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_functions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_next_notification_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_open_txns_info_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_part_specs_by_filter_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_expr_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_pspec_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_principals_in_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_grants_for_principal_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_statistics_req_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.getMetaConf_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_revoke_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.heartbeat_txn_range_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.lock_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.open_txns_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_has_valid_characters_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.rename_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_aggr_stats_for_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.set_ugi_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.setMetaConf_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_compact_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.show_locks_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.unlock_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.clean_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelDelegationToken_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CancelOperation_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseOperation_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.CloseSession_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.ExecuteStatement_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.FetchResults_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetCatalogs_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetColumns_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetDelegationToken_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetFunctions_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetInfo_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetOperationStatus_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetResultSetMetadata_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetSchemas_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTables_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTableTypes_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.GetTypeInfo_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.OpenSession_call
 
write_args(TProtocol) - Method in class org.apache.hive.service.cli.thrift.TCLIService.AsyncClient.RenewDelegationToken_call
 
writeArray(ArrayWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeBinary(ByteStream.Output, Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeBinary(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeBinary(byte[]) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeBinary(byte[], int, int) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeBinary(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeBinary(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeBinary(ByteBuffer) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(ByteBuffer) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a boolean as a typed bytes sequence.
writeBool(boolean, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeBoolean(BooleanWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeBoolean(boolean) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeBoolean(boolean) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeBoolean(boolean) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeBoolean(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeBoolean(boolean) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeBuffers() - Method in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastValueStore
A store for "lists" of arbitrary length values in memory.
WriteBuffers - Class in org.apache.hadoop.hive.serde2
The structure storing arbitrary amount of data as a set of fixed-size byte buffers.
WriteBuffers(int, long) - Constructor for class org.apache.hadoop.hive.serde2.WriteBuffers
 
WriteBuffers.ByteSegmentRef - Class in org.apache.hadoop.hive.serde2
The class representing a segment of bytes in the buffer.
WriteBuffers.ByteSegmentRef(long, int) - Constructor for class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
WriteBuffers.ByteSegmentRef() - Constructor for class org.apache.hadoop.hive.serde2.WriteBuffers.ByteSegmentRef
 
WriteBuffers.Position - Class in org.apache.hadoop.hive.serde2
 
WriteBuffers.Position() - Constructor for class org.apache.hadoop.hive.serde2.WriteBuffers.Position
 
writeBuffersSize - Variable in class org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable
 
writeByte(byte) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a byte as a typed bytes sequence.
writeByte(byte, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeByte(ByteWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeByte(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeByte(ByteStream.RandomAccessOutput, byte, boolean) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeByte(long, byte) - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
writeByte(long, byte) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
writeByte(byte) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeByte(long, byte) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
writeBytes(byte[], int) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence, using a given typecode.
writeBytes(byte[]) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence.
writeBytes(BytesWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeBytes(String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeBytes(long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
Reads some bytes from the buffer and writes them again at current write point.
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
 
writeDataTo(DataOutput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
writeDate(Date) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeDate(int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeDate(Date) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeDate(int) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeDate(Date) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeDate(int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeDate(Date) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeDate(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeDatum(DataOutput, Object) - Static method in class org.apache.hive.hcatalog.data.ReaderWriter
 
writeDouble(double) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a double as a typed bytes sequence.
writeDouble(double, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeDouble(DoubleWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeDouble(double) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeDouble(double) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeDouble(ByteStream.RandomAccessOutput, double) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeEndOfRecord() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
 
writeEndOfRecord() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
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(Database, String, Entity.Type, WriteEntity.WriteType) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for objects represented as String.
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 - Class in org.apache.hive.hcatalog.data.transfer
 
WriteEntity.Builder - Class in org.apache.hive.hcatalog.data.transfer
This class should be used to build WriteEntity.
WriteEntity.Builder() - Constructor for class org.apache.hive.hcatalog.data.transfer.WriteEntity.Builder
 
WriteEntity.WriteType - Enum in org.apache.hadoop.hive.ql.hooks
 
writeEscaped(OutputStream, byte[], int, int, boolean, byte, boolean[]) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Write the bytes with special characters escaped.
writeEventHeader(DataOutputBuffer) - Method in class org.apache.hadoop.hive.ql.plan.AppMasterEventDesc
 
writeEventHeader(DataOutputBuffer) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc
 
writeFieldBegin(TField) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeFieldBegin(TField) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeFieldEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeFieldEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeFieldStop() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeFieldStop() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeFiveByteULong(long, long) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
writeFloat(float) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a float as a typed bytes sequence.
writeFloat(float, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeFloat(FloatWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeFloat(float) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeFloat(float) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeFloat(float) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeFloat(float) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeFloat(float) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveChar(HiveChar) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveChar(HiveChar) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveChar(HiveChar) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveChar(HiveChar) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveDecimal(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveDecimal(HiveDecimal) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveDecimal(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveDecimal(HiveDecimal) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveIntervalDayTime(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveIntervalDayTime(long) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveIntervalDayTime(HiveIntervalDayTime) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveIntervalDayTime(long) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveIntervalDayTime(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveIntervalDayTime(long) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveIntervalDayTime(HiveIntervalDayTime) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveIntervalDayTime(long) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveIntervalYearMonth(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveIntervalYearMonth(int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveIntervalYearMonth(HiveIntervalYearMonth) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveIntervalYearMonth(int) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveIntervalYearMonth(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveIntervalYearMonth(int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveIntervalYearMonth(HiveIntervalYearMonth) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveIntervalYearMonth(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeHiveVarchar(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeHiveVarchar(HiveVarchar) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeHiveVarchar(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeHiveVarchar(HiveVarchar) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeI16(short) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeI16(short) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeI32(int) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeI32(int) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeI64(long) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeI64(long) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeInt(int) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes an integer as a typed bytes sequence.
writeInt(int, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeInt(IntWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeInt(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeInt(int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeInt(long, int) - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
writeInt(long, int) - Method in interface org.apache.hadoop.hive.serde2.ByteStream.RandomAccessOutput
 
writeInt(int) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeInt(int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeInt(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeInt(long, int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
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.
writeIntermediateFooter() - Method in class org.apache.hadoop.hive.ql.io.orc.WriterImpl
 
writeKey(ByteStream.RandomAccessOutput) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.KvSource
Write key into output.
writeKey(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
writeList(List) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a list as a typed bytes sequence.
writeListBegin(TList) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeListBegin(TList) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeListEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeListEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeListFooter() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a list footer.
writeListHeader() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a list header.
writeLong(long) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a long as a typed bytes sequence.
writeLong(long, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeLong(LongWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeLong(long) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeLong(long) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeLong(long) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeLong(long) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeLong(long) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeLongToUTF8(byte[], long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
writeMap(Map) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a map as a typed bytes sequence.
writeMap(MapWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeMapBegin(TMap) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeMapBegin(TMap) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeMapEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeMapEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeMapHeader(int) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a map header.
writeMessageBegin(TMessage) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeMessageBegin(TMessage) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeMessageEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeMessageEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeNull() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a NULL type marker to the output.
writeNull() - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeNull() - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeNull() - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeNull() - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeNull() - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeNull() - Method in interface org.apache.hadoop.hive.serde2.thrift.WriteNullsProtocol
Write a null.
WriteNullsProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that actually write out nulls - This should be for all those that don't actually use fieldids in the written data like TCTLSeparatedProtocol.
writeObject(Object) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeOperationLog(String) - Method in class org.apache.hadoop.hive.ql.session.OperationLog
Write operation execution logs into log file
writePartitionKeys(Path, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
writePrimitive(OutputStream, Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Write out a binary representation of a PrimitiveObject to a byte stream.
writePrimitiveUTF8(OutputStream, Object, PrimitiveObjectInspector, boolean, byte, boolean[]) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Write out the text representation of a Primitive Object to a UTF8 byte stream.
Writer - Interface in org.apache.hadoop.hive.ql.io.orc
The interface for writing ORC files.
writeRaw(byte[]) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
writeRaw(byte[], int, int) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
WriterContext - Interface in org.apache.hive.hcatalog.data.transfer
This contains information obtained at master node to be distributed to slaves nodes that will do the writing.
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
writeReplace() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
WriterImpl - Class in org.apache.hadoop.hive.ql.io.orc
An ORC file writer.
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.
WRITERTIMEZONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
WRITERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
writeSerializedPrimitive(PrimitiveObjectInspector, ByteStream.Output, Object, ColumnEncoding) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
Serialize the given primitive to the given output buffer, using the provided encoding mechanism.
writeSetBegin(TSet) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeSetBegin(TSet) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeSetEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeSetEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeShort(short) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a short as a typed bytes sequence.
writeShort(ShortWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeShort(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeShort(short) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeShort(short) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeShort(short) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeShort(short) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeString(ByteStream.Output, Object, PrimitiveObjectInspector) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
 
writeString(String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a string as a typed bytes sequence.
writeString(String, String) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesRecordOutput
 
writeString(byte[]) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeString(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeString(byte[]) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeString(byte[], int, int) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeString(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeString(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeString(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeString(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeStructBegin(TStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeStructBegin(TStruct) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeStructEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeStructEnd() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeText(Text) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeText(Text) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeText(Text) - Method in interface org.apache.hadoop.hive.serde2.thrift.WriteTextProtocol
Write Text.
WriteTextProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that can write out data in hadoop Text objects (UTF-8 encoded String).
writeTimestamp(Timestamp) - Method in class org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite
 
writeTimestamp(Timestamp) - Method in interface org.apache.hadoop.hive.serde2.fast.SerializeWrite
 
writeTimestamp(Timestamp) - Method in class org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite
 
writeTimestamp(Timestamp) - Method in class org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite
 
writeTo(OutputStream) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BinaryStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BloomFilterIndex
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.BucketStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnEncoding
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.ColumnStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DateStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DecimalStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.DoubleStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Footer
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.IntegerStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Metadata
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.PostScript
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndex
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.RowIndexEntry
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Stream
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StringStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeFooter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeInformation
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.StripeStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.TimestampStatistics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.Type
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcProto.UserMetadataItem
 
writeToByteStream(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.serde2.io.DateWritable
 
writeToByteStream(Decimal128, ByteStream.Output) - Static method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
writeToByteStream(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveDecimalWritable
 
writeToByteStream(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalDayTimeWritable
 
writeToByteStream(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.serde2.io.HiveIntervalYearMonthWritable
 
writeToByteStream(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.serde2.io.TimestampWritable
 
writeToString() - Method in class org.apache.hadoop.hive.common.ValidReadTxnList
 
writeToString() - Method in interface org.apache.hadoop.hive.common.ValidTxnList
Write this validTxnList into a string.
writeToString() - Method in class org.apache.hadoop.hive.metastore.txn.ValidCompactorTxnList
 
writeTypedBytes(TypedBytesWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeUTF(String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeUTF8(OutputStream, DateWritable) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyDate
Writes a Date in SQL date format to the output stream.
writeUTF8(OutputStream, HiveDecimal) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal
Writes HiveDecimal object to output stream as string
writeUTF8(OutputStream, HiveIntervalDayTimeWritable) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalDayTime
 
writeUTF8(OutputStream, HiveIntervalYearMonthWritable) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyHiveIntervalYearMonth
 
writeUTF8(OutputStream, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyInteger
Writes out the text representation of an integer using base 10 to an OutputStream in UTF-8 encoding.
writeUTF8(OutputStream, long) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyLong
Writes out the text representation of an integer using base 10 to an OutputStream in UTF-8 encoding.
writeUTF8(OutputStream, TimestampWritable) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyTimestamp
Writes a Timestamp in JDBC timestamp format to the output stream
writeUTF8NoException(OutputStream, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
writeUTF8NoException(OutputStream, long) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyLong
 
writeValue(ByteStream.RandomAccessOutput) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap.KvSource
Write value into output.
writeValue(ByteStream.RandomAccessOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer.DirectKeyValueWriter
 
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(HiveDecimalWritable) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(HiveDecimal) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(RecordConsumer) - Method in class org.apache.hadoop.hive.ql.io.parquet.timestamp.NanoTime
 
writeVector(ArrayList) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a vector as a typed bytes sequence.
writeVectorHeader(int) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesOutput
Writes a vector header.
writeVInt(VIntWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeVInt(ByteStream.RandomAccessOutput, int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Writes a zero-compressed encoded int to a byte array.
writeVInt(int) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
writeVLong(VLongWritable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
writeVLong(ByteStream.RandomAccessOutput, long) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
 
writeVLong(long) - Method in class org.apache.hadoop.hive.serde2.WriteBuffers
 
writeVLongToByteArray(byte[], long) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Write a zero-compressed encoded long to a byte array.
writeVLongToByteArray(byte[], int, long) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
 
writeWithLevel(ObjectInspector, Object, ByteStream.Output, ColumnMapping, int) - Method in class org.apache.hadoop.hive.accumulo.serde.AccumuloRowSerializer
Recursively serialize an Object using its ObjectInspector, respecting the separators defined by the LazySerDeParameters.
writeWritable(Writable) - Method in class org.apache.hadoop.hive.contrib.util.typedbytes.TypedBytesWritableOutput
 
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.
WS - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterLexer
 
WS - Static variable in class org.apache.hadoop.hive.metastore.parser.FilterParser
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_FromClauseParser
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_IdentifiersParser
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser_SelectClauseParser
 
WWW_AUTHENTICATE - Static variable in class org.apache.hive.service.auth.HttpAuthUtils
 

X

Xception() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
xequals(Object, Object) - Static method in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
xequals(boolean, boolean) - Static method in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
xequals(int, int) - Static method in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 
xequals(char, char) - Static method in class org.apache.hive.hcatalog.templeton.GroupPermissionsDesc
 

Z

ZERO - Static variable in class org.apache.hadoop.hive.common.type.HiveDecimal
 
ZERO - Static variable in class org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCost
 
ZeroBytesRefWritable - Static variable in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
zeroClear() - Method in class org.apache.hadoop.hive.common.type.Decimal128
Reset the value of this object to zero.
zeroClear() - Method in class org.apache.hadoop.hive.common.type.SignedInt128
Make the value to zero.
zeroClear() - Method in class org.apache.hadoop.hive.common.type.UnsignedInt128
Make the value to zero.
zeroFractionPart(UnsignedInt128) - Method in class org.apache.hadoop.hive.common.type.Decimal128
Zero the fractional part of value.
zeroFractionPart() - Method in class org.apache.hadoop.hive.common.type.Decimal128
 
ZK_CLEANUP_INTERVAL - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
ZK_CLEANUP_MAX_AGE - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperCleanup
 
ZK_HOSTS - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
ZK_SEQ_FORMAT - Static variable in class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
 
ZK_SESSION_TIMEOUT - Static variable in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
zkCleanupInterval() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
zkHosts() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
zkMaxAge() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
zkOpen(String, int) - Static method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Open a ZooKeeper connection for the JobState.
zkOpen(Configuration) - Static method in class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
Open a ZooKeeper connection for the JobState.
zkSessionTimeout() - Method in class org.apache.hive.hcatalog.templeton.AppConfig
 
ZLIB_VALUE - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcProto.CompressionKind
ZLIB = 1;
ZOOKEEPER_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper
 
ZooKeeperCleanup - Class in org.apache.hive.hcatalog.templeton.tool
This does periodic cleanup
ZooKeeperHiveClientException - Exception in org.apache.hive.jdbc
 
ZooKeeperHiveClientException(Throwable) - Constructor for exception org.apache.hive.jdbc.ZooKeeperHiveClientException
 
ZooKeeperHiveClientException(String) - Constructor for exception org.apache.hive.jdbc.ZooKeeperHiveClientException
 
ZooKeeperHiveClientException(String, Throwable) - Constructor for exception org.apache.hive.jdbc.ZooKeeperHiveClientException
 
ZooKeeperHiveClientHelper - Class in org.apache.hive.jdbc
 
ZooKeeperHiveClientHelper() - Constructor for class org.apache.hive.jdbc.ZooKeeperHiveClientHelper
 
ZooKeeperHiveClientHelper.DummyWatcher - Class in org.apache.hive.jdbc
A no-op watcher class
ZooKeeperHiveClientHelper.DummyWatcher() - Constructor for class org.apache.hive.jdbc.ZooKeeperHiveClientHelper.DummyWatcher
 
ZooKeeperHiveHelper - Class in org.apache.hadoop.hive.ql.util
 
ZooKeeperHiveHelper() - Constructor for class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper
 
ZooKeeperHiveHelper.DummyWatcher - Class in org.apache.hadoop.hive.ql.util
A no-op watcher class
ZooKeeperHiveHelper.DummyWatcher() - Constructor for class org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper.DummyWatcher
 
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
 
ZOOKEEPERS - Static variable in class org.apache.hadoop.hive.accumulo.AccumuloConnectionParameters
 
ZooKeeperStorage - Class in org.apache.hive.hcatalog.templeton.tool
A storage implementation based on storing everything in ZooKeeper.
ZooKeeperStorage() - Constructor for class org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage
 
ZooKeeperTokenStore - Class in org.apache.hadoop.hive.thrift
ZooKeeper token store implementation.
ZooKeeperTokenStore() - Constructor for class org.apache.hadoop.hive.thrift.ZooKeeperTokenStore
Default constructor for dynamic instantiation w/ Configurable (ReflectionUtils does not support Configuration constructor injection).

_

_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeColumnEvaluator
 
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Evaluate value
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorHead
 
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorRef
 
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
_evaluate(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
_getFnName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLag
 
_getFnName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLead
 
_getFnName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
_transformRawInput(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap
 
_transformRawInput(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
_tryStoreKey(HiveKey, boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.PTFTopNHash
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 

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